PUT CancelImageCreation
{{baseUrl}}/CancelImageCreation
BODY json

{
  "imageBuildVersionArn": "",
  "clientToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

(client/put "{{baseUrl}}/CancelImageCreation" {:content-type :json
                                                               :form-params {:imageBuildVersionArn ""
                                                                             :clientToken ""}})
require "http/client"

url = "{{baseUrl}}/CancelImageCreation"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"imageBuildVersionArn\": \"\",\n  \"clientToken\": \"\"\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}}/CancelImageCreation"),
    Content = new StringContent("{\n  \"imageBuildVersionArn\": \"\",\n  \"clientToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/CancelImageCreation");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"imageBuildVersionArn\": \"\",\n  \"clientToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

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

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/CancelImageCreation"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"imageBuildVersionArn\": \"\",\n  \"clientToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"imageBuildVersionArn\": \"\",\n  \"clientToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/CancelImageCreation")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

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

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CancelImageCreation',
  headers: {'content-type': 'application/json'},
  data: {imageBuildVersionArn: '', clientToken: ''}
};

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

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

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"imageBuildVersionArn\": \"\",\n  \"clientToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/CancelImageCreation")
  .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/CancelImageCreation',
  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({imageBuildVersionArn: '', clientToken: ''}));
req.end();
const request = require('request');

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

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

req.type('json');
req.send({
  imageBuildVersionArn: '',
  clientToken: ''
});

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}}/CancelImageCreation',
  headers: {'content-type': 'application/json'},
  data: {imageBuildVersionArn: '', clientToken: ''}
};

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

const url = '{{baseUrl}}/CancelImageCreation';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"imageBuildVersionArn":"","clientToken":""}'
};

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

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

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

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

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

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

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

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

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

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

payload = "{\n  \"imageBuildVersionArn\": \"\",\n  \"clientToken\": \"\"\n}"

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

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

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

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

url = "{{baseUrl}}/CancelImageCreation"

payload = {
    "imageBuildVersionArn": "",
    "clientToken": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"imageBuildVersionArn\": \"\",\n  \"clientToken\": \"\"\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}}/CancelImageCreation")

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  \"imageBuildVersionArn\": \"\",\n  \"clientToken\": \"\"\n}"

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

    let payload = json!({
        "imageBuildVersionArn": "",
        "clientToken": ""
    });

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/CancelImageCreation")! 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 CreateComponent
{{baseUrl}}/CreateComponent
BODY json

{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "platform": "",
  "supportedOsVersions": [],
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}");

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

(client/put "{{baseUrl}}/CreateComponent" {:content-type :json
                                                           :form-params {:name ""
                                                                         :semanticVersion ""
                                                                         :description ""
                                                                         :changeDescription ""
                                                                         :platform ""
                                                                         :supportedOsVersions []
                                                                         :data ""
                                                                         :uri ""
                                                                         :kmsKeyId ""
                                                                         :tags {}
                                                                         :clientToken ""}})
require "http/client"

url = "{{baseUrl}}/CreateComponent"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/CreateComponent"),
    Content = new StringContent("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/CreateComponent");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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/CreateComponent HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 216

{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "platform": "",
  "supportedOsVersions": [],
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/CreateComponent")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/CreateComponent"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/CreateComponent")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/CreateComponent")
  .header("content-type", "application/json")
  .body("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  name: '',
  semanticVersion: '',
  description: '',
  changeDescription: '',
  platform: '',
  supportedOsVersions: [],
  data: '',
  uri: '',
  kmsKeyId: '',
  tags: {},
  clientToken: ''
});

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateComponent',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    semanticVersion: '',
    description: '',
    changeDescription: '',
    platform: '',
    supportedOsVersions: [],
    data: '',
    uri: '',
    kmsKeyId: '',
    tags: {},
    clientToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/CreateComponent';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","semanticVersion":"","description":"","changeDescription":"","platform":"","supportedOsVersions":[],"data":"","uri":"","kmsKeyId":"","tags":{},"clientToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/CreateComponent',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name": "",\n  "semanticVersion": "",\n  "description": "",\n  "changeDescription": "",\n  "platform": "",\n  "supportedOsVersions": [],\n  "data": "",\n  "uri": "",\n  "kmsKeyId": "",\n  "tags": {},\n  "clientToken": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/CreateComponent")
  .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/CreateComponent',
  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({
  name: '',
  semanticVersion: '',
  description: '',
  changeDescription: '',
  platform: '',
  supportedOsVersions: [],
  data: '',
  uri: '',
  kmsKeyId: '',
  tags: {},
  clientToken: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateComponent',
  headers: {'content-type': 'application/json'},
  body: {
    name: '',
    semanticVersion: '',
    description: '',
    changeDescription: '',
    platform: '',
    supportedOsVersions: [],
    data: '',
    uri: '',
    kmsKeyId: '',
    tags: {},
    clientToken: ''
  },
  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}}/CreateComponent');

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

req.type('json');
req.send({
  name: '',
  semanticVersion: '',
  description: '',
  changeDescription: '',
  platform: '',
  supportedOsVersions: [],
  data: '',
  uri: '',
  kmsKeyId: '',
  tags: {},
  clientToken: ''
});

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}}/CreateComponent',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    semanticVersion: '',
    description: '',
    changeDescription: '',
    platform: '',
    supportedOsVersions: [],
    data: '',
    uri: '',
    kmsKeyId: '',
    tags: {},
    clientToken: ''
  }
};

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

const url = '{{baseUrl}}/CreateComponent';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","semanticVersion":"","description":"","changeDescription":"","platform":"","supportedOsVersions":[],"data":"","uri":"","kmsKeyId":"","tags":{},"clientToken":""}'
};

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 = @{ @"name": @"",
                              @"semanticVersion": @"",
                              @"description": @"",
                              @"changeDescription": @"",
                              @"platform": @"",
                              @"supportedOsVersions": @[  ],
                              @"data": @"",
                              @"uri": @"",
                              @"kmsKeyId": @"",
                              @"tags": @{  },
                              @"clientToken": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/CreateComponent"]
                                                       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}}/CreateComponent" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/CreateComponent",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'name' => '',
    'semanticVersion' => '',
    'description' => '',
    'changeDescription' => '',
    'platform' => '',
    'supportedOsVersions' => [
        
    ],
    'data' => '',
    'uri' => '',
    'kmsKeyId' => '',
    'tags' => [
        
    ],
    'clientToken' => ''
  ]),
  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}}/CreateComponent', [
  'body' => '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "platform": "",
  "supportedOsVersions": [],
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name' => '',
  'semanticVersion' => '',
  'description' => '',
  'changeDescription' => '',
  'platform' => '',
  'supportedOsVersions' => [
    
  ],
  'data' => '',
  'uri' => '',
  'kmsKeyId' => '',
  'tags' => [
    
  ],
  'clientToken' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name' => '',
  'semanticVersion' => '',
  'description' => '',
  'changeDescription' => '',
  'platform' => '',
  'supportedOsVersions' => [
    
  ],
  'data' => '',
  'uri' => '',
  'kmsKeyId' => '',
  'tags' => [
    
  ],
  'clientToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/CreateComponent');
$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}}/CreateComponent' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "platform": "",
  "supportedOsVersions": [],
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/CreateComponent' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "platform": "",
  "supportedOsVersions": [],
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}'
import http.client

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

payload = "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"

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

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

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

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

url = "{{baseUrl}}/CreateComponent"

payload = {
    "name": "",
    "semanticVersion": "",
    "description": "",
    "changeDescription": "",
    "platform": "",
    "supportedOsVersions": [],
    "data": "",
    "uri": "",
    "kmsKeyId": "",
    "tags": {},
    "clientToken": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/CreateComponent")

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  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"

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/CreateComponent') do |req|
  req.body = "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"platform\": \"\",\n  \"supportedOsVersions\": [],\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/CreateComponent";

    let payload = json!({
        "name": "",
        "semanticVersion": "",
        "description": "",
        "changeDescription": "",
        "platform": "",
        "supportedOsVersions": (),
        "data": "",
        "uri": "",
        "kmsKeyId": "",
        "tags": json!({}),
        "clientToken": ""
    });

    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}}/CreateComponent \
  --header 'content-type: application/json' \
  --data '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "platform": "",
  "supportedOsVersions": [],
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}'
echo '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "platform": "",
  "supportedOsVersions": [],
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}' |  \
  http PUT {{baseUrl}}/CreateComponent \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": "",\n  "semanticVersion": "",\n  "description": "",\n  "changeDescription": "",\n  "platform": "",\n  "supportedOsVersions": [],\n  "data": "",\n  "uri": "",\n  "kmsKeyId": "",\n  "tags": {},\n  "clientToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/CreateComponent
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "platform": "",
  "supportedOsVersions": [],
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": [],
  "clientToken": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/CreateComponent")! 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 CreateContainerRecipe
{{baseUrl}}/CreateContainerRecipe
BODY json

{
  "containerType": "",
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "instanceConfiguration": {
    "image": "",
    "blockDeviceMappings": ""
  },
  "dockerfileTemplateData": "",
  "dockerfileTemplateUri": "",
  "platformOverride": "",
  "imageOsVersionOverride": "",
  "parentImage": "",
  "tags": {},
  "workingDirectory": "",
  "targetRepository": {
    "service": "",
    "repositoryName": ""
  },
  "kmsKeyId": "",
  "clientToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\n}");

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

(client/put "{{baseUrl}}/CreateContainerRecipe" {:content-type :json
                                                                 :form-params {:containerType ""
                                                                               :name ""
                                                                               :description ""
                                                                               :semanticVersion ""
                                                                               :components [{:componentArn ""
                                                                                             :parameters ""}]
                                                                               :instanceConfiguration {:image ""
                                                                                                       :blockDeviceMappings ""}
                                                                               :dockerfileTemplateData ""
                                                                               :dockerfileTemplateUri ""
                                                                               :platformOverride ""
                                                                               :imageOsVersionOverride ""
                                                                               :parentImage ""
                                                                               :tags {}
                                                                               :workingDirectory ""
                                                                               :targetRepository {:service ""
                                                                                                  :repositoryName ""}
                                                                               :kmsKeyId ""
                                                                               :clientToken ""}})
require "http/client"

url = "{{baseUrl}}/CreateContainerRecipe"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\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}}/CreateContainerRecipe"),
    Content = new StringContent("{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/CreateContainerRecipe");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\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/CreateContainerRecipe HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 544

{
  "containerType": "",
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "instanceConfiguration": {
    "image": "",
    "blockDeviceMappings": ""
  },
  "dockerfileTemplateData": "",
  "dockerfileTemplateUri": "",
  "platformOverride": "",
  "imageOsVersionOverride": "",
  "parentImage": "",
  "tags": {},
  "workingDirectory": "",
  "targetRepository": {
    "service": "",
    "repositoryName": ""
  },
  "kmsKeyId": "",
  "clientToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/CreateContainerRecipe")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/CreateContainerRecipe"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/CreateContainerRecipe")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/CreateContainerRecipe")
  .header("content-type", "application/json")
  .body("{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  containerType: '',
  name: '',
  description: '',
  semanticVersion: '',
  components: [
    {
      componentArn: '',
      parameters: ''
    }
  ],
  instanceConfiguration: {
    image: '',
    blockDeviceMappings: ''
  },
  dockerfileTemplateData: '',
  dockerfileTemplateUri: '',
  platformOverride: '',
  imageOsVersionOverride: '',
  parentImage: '',
  tags: {},
  workingDirectory: '',
  targetRepository: {
    service: '',
    repositoryName: ''
  },
  kmsKeyId: '',
  clientToken: ''
});

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateContainerRecipe',
  headers: {'content-type': 'application/json'},
  data: {
    containerType: '',
    name: '',
    description: '',
    semanticVersion: '',
    components: [{componentArn: '', parameters: ''}],
    instanceConfiguration: {image: '', blockDeviceMappings: ''},
    dockerfileTemplateData: '',
    dockerfileTemplateUri: '',
    platformOverride: '',
    imageOsVersionOverride: '',
    parentImage: '',
    tags: {},
    workingDirectory: '',
    targetRepository: {service: '', repositoryName: ''},
    kmsKeyId: '',
    clientToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/CreateContainerRecipe';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"containerType":"","name":"","description":"","semanticVersion":"","components":[{"componentArn":"","parameters":""}],"instanceConfiguration":{"image":"","blockDeviceMappings":""},"dockerfileTemplateData":"","dockerfileTemplateUri":"","platformOverride":"","imageOsVersionOverride":"","parentImage":"","tags":{},"workingDirectory":"","targetRepository":{"service":"","repositoryName":""},"kmsKeyId":"","clientToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/CreateContainerRecipe',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "containerType": "",\n  "name": "",\n  "description": "",\n  "semanticVersion": "",\n  "components": [\n    {\n      "componentArn": "",\n      "parameters": ""\n    }\n  ],\n  "instanceConfiguration": {\n    "image": "",\n    "blockDeviceMappings": ""\n  },\n  "dockerfileTemplateData": "",\n  "dockerfileTemplateUri": "",\n  "platformOverride": "",\n  "imageOsVersionOverride": "",\n  "parentImage": "",\n  "tags": {},\n  "workingDirectory": "",\n  "targetRepository": {\n    "service": "",\n    "repositoryName": ""\n  },\n  "kmsKeyId": "",\n  "clientToken": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/CreateContainerRecipe")
  .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/CreateContainerRecipe',
  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({
  containerType: '',
  name: '',
  description: '',
  semanticVersion: '',
  components: [{componentArn: '', parameters: ''}],
  instanceConfiguration: {image: '', blockDeviceMappings: ''},
  dockerfileTemplateData: '',
  dockerfileTemplateUri: '',
  platformOverride: '',
  imageOsVersionOverride: '',
  parentImage: '',
  tags: {},
  workingDirectory: '',
  targetRepository: {service: '', repositoryName: ''},
  kmsKeyId: '',
  clientToken: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateContainerRecipe',
  headers: {'content-type': 'application/json'},
  body: {
    containerType: '',
    name: '',
    description: '',
    semanticVersion: '',
    components: [{componentArn: '', parameters: ''}],
    instanceConfiguration: {image: '', blockDeviceMappings: ''},
    dockerfileTemplateData: '',
    dockerfileTemplateUri: '',
    platformOverride: '',
    imageOsVersionOverride: '',
    parentImage: '',
    tags: {},
    workingDirectory: '',
    targetRepository: {service: '', repositoryName: ''},
    kmsKeyId: '',
    clientToken: ''
  },
  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}}/CreateContainerRecipe');

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

req.type('json');
req.send({
  containerType: '',
  name: '',
  description: '',
  semanticVersion: '',
  components: [
    {
      componentArn: '',
      parameters: ''
    }
  ],
  instanceConfiguration: {
    image: '',
    blockDeviceMappings: ''
  },
  dockerfileTemplateData: '',
  dockerfileTemplateUri: '',
  platformOverride: '',
  imageOsVersionOverride: '',
  parentImage: '',
  tags: {},
  workingDirectory: '',
  targetRepository: {
    service: '',
    repositoryName: ''
  },
  kmsKeyId: '',
  clientToken: ''
});

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}}/CreateContainerRecipe',
  headers: {'content-type': 'application/json'},
  data: {
    containerType: '',
    name: '',
    description: '',
    semanticVersion: '',
    components: [{componentArn: '', parameters: ''}],
    instanceConfiguration: {image: '', blockDeviceMappings: ''},
    dockerfileTemplateData: '',
    dockerfileTemplateUri: '',
    platformOverride: '',
    imageOsVersionOverride: '',
    parentImage: '',
    tags: {},
    workingDirectory: '',
    targetRepository: {service: '', repositoryName: ''},
    kmsKeyId: '',
    clientToken: ''
  }
};

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

const url = '{{baseUrl}}/CreateContainerRecipe';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"containerType":"","name":"","description":"","semanticVersion":"","components":[{"componentArn":"","parameters":""}],"instanceConfiguration":{"image":"","blockDeviceMappings":""},"dockerfileTemplateData":"","dockerfileTemplateUri":"","platformOverride":"","imageOsVersionOverride":"","parentImage":"","tags":{},"workingDirectory":"","targetRepository":{"service":"","repositoryName":""},"kmsKeyId":"","clientToken":""}'
};

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 = @{ @"containerType": @"",
                              @"name": @"",
                              @"description": @"",
                              @"semanticVersion": @"",
                              @"components": @[ @{ @"componentArn": @"", @"parameters": @"" } ],
                              @"instanceConfiguration": @{ @"image": @"", @"blockDeviceMappings": @"" },
                              @"dockerfileTemplateData": @"",
                              @"dockerfileTemplateUri": @"",
                              @"platformOverride": @"",
                              @"imageOsVersionOverride": @"",
                              @"parentImage": @"",
                              @"tags": @{  },
                              @"workingDirectory": @"",
                              @"targetRepository": @{ @"service": @"", @"repositoryName": @"" },
                              @"kmsKeyId": @"",
                              @"clientToken": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/CreateContainerRecipe"]
                                                       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}}/CreateContainerRecipe" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/CreateContainerRecipe",
  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([
    'containerType' => '',
    'name' => '',
    'description' => '',
    'semanticVersion' => '',
    'components' => [
        [
                'componentArn' => '',
                'parameters' => ''
        ]
    ],
    'instanceConfiguration' => [
        'image' => '',
        'blockDeviceMappings' => ''
    ],
    'dockerfileTemplateData' => '',
    'dockerfileTemplateUri' => '',
    'platformOverride' => '',
    'imageOsVersionOverride' => '',
    'parentImage' => '',
    'tags' => [
        
    ],
    'workingDirectory' => '',
    'targetRepository' => [
        'service' => '',
        'repositoryName' => ''
    ],
    'kmsKeyId' => '',
    'clientToken' => ''
  ]),
  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}}/CreateContainerRecipe', [
  'body' => '{
  "containerType": "",
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "instanceConfiguration": {
    "image": "",
    "blockDeviceMappings": ""
  },
  "dockerfileTemplateData": "",
  "dockerfileTemplateUri": "",
  "platformOverride": "",
  "imageOsVersionOverride": "",
  "parentImage": "",
  "tags": {},
  "workingDirectory": "",
  "targetRepository": {
    "service": "",
    "repositoryName": ""
  },
  "kmsKeyId": "",
  "clientToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'containerType' => '',
  'name' => '',
  'description' => '',
  'semanticVersion' => '',
  'components' => [
    [
        'componentArn' => '',
        'parameters' => ''
    ]
  ],
  'instanceConfiguration' => [
    'image' => '',
    'blockDeviceMappings' => ''
  ],
  'dockerfileTemplateData' => '',
  'dockerfileTemplateUri' => '',
  'platformOverride' => '',
  'imageOsVersionOverride' => '',
  'parentImage' => '',
  'tags' => [
    
  ],
  'workingDirectory' => '',
  'targetRepository' => [
    'service' => '',
    'repositoryName' => ''
  ],
  'kmsKeyId' => '',
  'clientToken' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'containerType' => '',
  'name' => '',
  'description' => '',
  'semanticVersion' => '',
  'components' => [
    [
        'componentArn' => '',
        'parameters' => ''
    ]
  ],
  'instanceConfiguration' => [
    'image' => '',
    'blockDeviceMappings' => ''
  ],
  'dockerfileTemplateData' => '',
  'dockerfileTemplateUri' => '',
  'platformOverride' => '',
  'imageOsVersionOverride' => '',
  'parentImage' => '',
  'tags' => [
    
  ],
  'workingDirectory' => '',
  'targetRepository' => [
    'service' => '',
    'repositoryName' => ''
  ],
  'kmsKeyId' => '',
  'clientToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/CreateContainerRecipe');
$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}}/CreateContainerRecipe' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "containerType": "",
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "instanceConfiguration": {
    "image": "",
    "blockDeviceMappings": ""
  },
  "dockerfileTemplateData": "",
  "dockerfileTemplateUri": "",
  "platformOverride": "",
  "imageOsVersionOverride": "",
  "parentImage": "",
  "tags": {},
  "workingDirectory": "",
  "targetRepository": {
    "service": "",
    "repositoryName": ""
  },
  "kmsKeyId": "",
  "clientToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/CreateContainerRecipe' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "containerType": "",
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "instanceConfiguration": {
    "image": "",
    "blockDeviceMappings": ""
  },
  "dockerfileTemplateData": "",
  "dockerfileTemplateUri": "",
  "platformOverride": "",
  "imageOsVersionOverride": "",
  "parentImage": "",
  "tags": {},
  "workingDirectory": "",
  "targetRepository": {
    "service": "",
    "repositoryName": ""
  },
  "kmsKeyId": "",
  "clientToken": ""
}'
import http.client

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

payload = "{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\n}"

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

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

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

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

url = "{{baseUrl}}/CreateContainerRecipe"

payload = {
    "containerType": "",
    "name": "",
    "description": "",
    "semanticVersion": "",
    "components": [
        {
            "componentArn": "",
            "parameters": ""
        }
    ],
    "instanceConfiguration": {
        "image": "",
        "blockDeviceMappings": ""
    },
    "dockerfileTemplateData": "",
    "dockerfileTemplateUri": "",
    "platformOverride": "",
    "imageOsVersionOverride": "",
    "parentImage": "",
    "tags": {},
    "workingDirectory": "",
    "targetRepository": {
        "service": "",
        "repositoryName": ""
    },
    "kmsKeyId": "",
    "clientToken": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\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}}/CreateContainerRecipe")

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  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\n}"

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/CreateContainerRecipe') do |req|
  req.body = "{\n  \"containerType\": \"\",\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"instanceConfiguration\": {\n    \"image\": \"\",\n    \"blockDeviceMappings\": \"\"\n  },\n  \"dockerfileTemplateData\": \"\",\n  \"dockerfileTemplateUri\": \"\",\n  \"platformOverride\": \"\",\n  \"imageOsVersionOverride\": \"\",\n  \"parentImage\": \"\",\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"targetRepository\": {\n    \"service\": \"\",\n    \"repositoryName\": \"\"\n  },\n  \"kmsKeyId\": \"\",\n  \"clientToken\": \"\"\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}}/CreateContainerRecipe";

    let payload = json!({
        "containerType": "",
        "name": "",
        "description": "",
        "semanticVersion": "",
        "components": (
            json!({
                "componentArn": "",
                "parameters": ""
            })
        ),
        "instanceConfiguration": json!({
            "image": "",
            "blockDeviceMappings": ""
        }),
        "dockerfileTemplateData": "",
        "dockerfileTemplateUri": "",
        "platformOverride": "",
        "imageOsVersionOverride": "",
        "parentImage": "",
        "tags": json!({}),
        "workingDirectory": "",
        "targetRepository": json!({
            "service": "",
            "repositoryName": ""
        }),
        "kmsKeyId": "",
        "clientToken": ""
    });

    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}}/CreateContainerRecipe \
  --header 'content-type: application/json' \
  --data '{
  "containerType": "",
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "instanceConfiguration": {
    "image": "",
    "blockDeviceMappings": ""
  },
  "dockerfileTemplateData": "",
  "dockerfileTemplateUri": "",
  "platformOverride": "",
  "imageOsVersionOverride": "",
  "parentImage": "",
  "tags": {},
  "workingDirectory": "",
  "targetRepository": {
    "service": "",
    "repositoryName": ""
  },
  "kmsKeyId": "",
  "clientToken": ""
}'
echo '{
  "containerType": "",
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "instanceConfiguration": {
    "image": "",
    "blockDeviceMappings": ""
  },
  "dockerfileTemplateData": "",
  "dockerfileTemplateUri": "",
  "platformOverride": "",
  "imageOsVersionOverride": "",
  "parentImage": "",
  "tags": {},
  "workingDirectory": "",
  "targetRepository": {
    "service": "",
    "repositoryName": ""
  },
  "kmsKeyId": "",
  "clientToken": ""
}' |  \
  http PUT {{baseUrl}}/CreateContainerRecipe \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "containerType": "",\n  "name": "",\n  "description": "",\n  "semanticVersion": "",\n  "components": [\n    {\n      "componentArn": "",\n      "parameters": ""\n    }\n  ],\n  "instanceConfiguration": {\n    "image": "",\n    "blockDeviceMappings": ""\n  },\n  "dockerfileTemplateData": "",\n  "dockerfileTemplateUri": "",\n  "platformOverride": "",\n  "imageOsVersionOverride": "",\n  "parentImage": "",\n  "tags": {},\n  "workingDirectory": "",\n  "targetRepository": {\n    "service": "",\n    "repositoryName": ""\n  },\n  "kmsKeyId": "",\n  "clientToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/CreateContainerRecipe
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "containerType": "",
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    [
      "componentArn": "",
      "parameters": ""
    ]
  ],
  "instanceConfiguration": [
    "image": "",
    "blockDeviceMappings": ""
  ],
  "dockerfileTemplateData": "",
  "dockerfileTemplateUri": "",
  "platformOverride": "",
  "imageOsVersionOverride": "",
  "parentImage": "",
  "tags": [],
  "workingDirectory": "",
  "targetRepository": [
    "service": "",
    "repositoryName": ""
  ],
  "kmsKeyId": "",
  "clientToken": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/CreateContainerRecipe")! 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 CreateDistributionConfiguration
{{baseUrl}}/CreateDistributionConfiguration
BODY json

{
  "name": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "tags": {},
  "clientToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\n}");

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

(client/put "{{baseUrl}}/CreateDistributionConfiguration" {:content-type :json
                                                                           :form-params {:name ""
                                                                                         :description ""
                                                                                         :distributions [{:region ""
                                                                                                          :amiDistributionConfiguration ""
                                                                                                          :containerDistributionConfiguration ""
                                                                                                          :licenseConfigurationArns ""
                                                                                                          :launchTemplateConfigurations ""
                                                                                                          :s3ExportConfiguration ""
                                                                                                          :fastLaunchConfigurations ""}]
                                                                                         :tags {}
                                                                                         :clientToken ""}})
require "http/client"

url = "{{baseUrl}}/CreateDistributionConfiguration"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/CreateDistributionConfiguration"),
    Content = new StringContent("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/CreateDistributionConfiguration");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\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/CreateDistributionConfiguration HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 372

{
  "name": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "tags": {},
  "clientToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/CreateDistributionConfiguration")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/CreateDistributionConfiguration"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/CreateDistributionConfiguration")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/CreateDistributionConfiguration")
  .header("content-type", "application/json")
  .body("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  name: '',
  description: '',
  distributions: [
    {
      region: '',
      amiDistributionConfiguration: '',
      containerDistributionConfiguration: '',
      licenseConfigurationArns: '',
      launchTemplateConfigurations: '',
      s3ExportConfiguration: '',
      fastLaunchConfigurations: ''
    }
  ],
  tags: {},
  clientToken: ''
});

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateDistributionConfiguration',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    description: '',
    distributions: [
      {
        region: '',
        amiDistributionConfiguration: '',
        containerDistributionConfiguration: '',
        licenseConfigurationArns: '',
        launchTemplateConfigurations: '',
        s3ExportConfiguration: '',
        fastLaunchConfigurations: ''
      }
    ],
    tags: {},
    clientToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/CreateDistributionConfiguration';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","description":"","distributions":[{"region":"","amiDistributionConfiguration":"","containerDistributionConfiguration":"","licenseConfigurationArns":"","launchTemplateConfigurations":"","s3ExportConfiguration":"","fastLaunchConfigurations":""}],"tags":{},"clientToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/CreateDistributionConfiguration',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name": "",\n  "description": "",\n  "distributions": [\n    {\n      "region": "",\n      "amiDistributionConfiguration": "",\n      "containerDistributionConfiguration": "",\n      "licenseConfigurationArns": "",\n      "launchTemplateConfigurations": "",\n      "s3ExportConfiguration": "",\n      "fastLaunchConfigurations": ""\n    }\n  ],\n  "tags": {},\n  "clientToken": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/CreateDistributionConfiguration")
  .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/CreateDistributionConfiguration',
  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({
  name: '',
  description: '',
  distributions: [
    {
      region: '',
      amiDistributionConfiguration: '',
      containerDistributionConfiguration: '',
      licenseConfigurationArns: '',
      launchTemplateConfigurations: '',
      s3ExportConfiguration: '',
      fastLaunchConfigurations: ''
    }
  ],
  tags: {},
  clientToken: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateDistributionConfiguration',
  headers: {'content-type': 'application/json'},
  body: {
    name: '',
    description: '',
    distributions: [
      {
        region: '',
        amiDistributionConfiguration: '',
        containerDistributionConfiguration: '',
        licenseConfigurationArns: '',
        launchTemplateConfigurations: '',
        s3ExportConfiguration: '',
        fastLaunchConfigurations: ''
      }
    ],
    tags: {},
    clientToken: ''
  },
  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}}/CreateDistributionConfiguration');

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

req.type('json');
req.send({
  name: '',
  description: '',
  distributions: [
    {
      region: '',
      amiDistributionConfiguration: '',
      containerDistributionConfiguration: '',
      licenseConfigurationArns: '',
      launchTemplateConfigurations: '',
      s3ExportConfiguration: '',
      fastLaunchConfigurations: ''
    }
  ],
  tags: {},
  clientToken: ''
});

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}}/CreateDistributionConfiguration',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    description: '',
    distributions: [
      {
        region: '',
        amiDistributionConfiguration: '',
        containerDistributionConfiguration: '',
        licenseConfigurationArns: '',
        launchTemplateConfigurations: '',
        s3ExportConfiguration: '',
        fastLaunchConfigurations: ''
      }
    ],
    tags: {},
    clientToken: ''
  }
};

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

const url = '{{baseUrl}}/CreateDistributionConfiguration';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","description":"","distributions":[{"region":"","amiDistributionConfiguration":"","containerDistributionConfiguration":"","licenseConfigurationArns":"","launchTemplateConfigurations":"","s3ExportConfiguration":"","fastLaunchConfigurations":""}],"tags":{},"clientToken":""}'
};

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 = @{ @"name": @"",
                              @"description": @"",
                              @"distributions": @[ @{ @"region": @"", @"amiDistributionConfiguration": @"", @"containerDistributionConfiguration": @"", @"licenseConfigurationArns": @"", @"launchTemplateConfigurations": @"", @"s3ExportConfiguration": @"", @"fastLaunchConfigurations": @"" } ],
                              @"tags": @{  },
                              @"clientToken": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/CreateDistributionConfiguration"]
                                                       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}}/CreateDistributionConfiguration" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/CreateDistributionConfiguration",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'name' => '',
    'description' => '',
    'distributions' => [
        [
                'region' => '',
                'amiDistributionConfiguration' => '',
                'containerDistributionConfiguration' => '',
                'licenseConfigurationArns' => '',
                'launchTemplateConfigurations' => '',
                's3ExportConfiguration' => '',
                'fastLaunchConfigurations' => ''
        ]
    ],
    'tags' => [
        
    ],
    'clientToken' => ''
  ]),
  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}}/CreateDistributionConfiguration', [
  'body' => '{
  "name": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "tags": {},
  "clientToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name' => '',
  'description' => '',
  'distributions' => [
    [
        'region' => '',
        'amiDistributionConfiguration' => '',
        'containerDistributionConfiguration' => '',
        'licenseConfigurationArns' => '',
        'launchTemplateConfigurations' => '',
        's3ExportConfiguration' => '',
        'fastLaunchConfigurations' => ''
    ]
  ],
  'tags' => [
    
  ],
  'clientToken' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name' => '',
  'description' => '',
  'distributions' => [
    [
        'region' => '',
        'amiDistributionConfiguration' => '',
        'containerDistributionConfiguration' => '',
        'licenseConfigurationArns' => '',
        'launchTemplateConfigurations' => '',
        's3ExportConfiguration' => '',
        'fastLaunchConfigurations' => ''
    ]
  ],
  'tags' => [
    
  ],
  'clientToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/CreateDistributionConfiguration');
$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}}/CreateDistributionConfiguration' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "tags": {},
  "clientToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/CreateDistributionConfiguration' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "tags": {},
  "clientToken": ""
}'
import http.client

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

payload = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"

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

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

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

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

url = "{{baseUrl}}/CreateDistributionConfiguration"

payload = {
    "name": "",
    "description": "",
    "distributions": [
        {
            "region": "",
            "amiDistributionConfiguration": "",
            "containerDistributionConfiguration": "",
            "licenseConfigurationArns": "",
            "launchTemplateConfigurations": "",
            "s3ExportConfiguration": "",
            "fastLaunchConfigurations": ""
        }
    ],
    "tags": {},
    "clientToken": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/CreateDistributionConfiguration")

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  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"

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/CreateDistributionConfiguration') do |req|
  req.body = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/CreateDistributionConfiguration";

    let payload = json!({
        "name": "",
        "description": "",
        "distributions": (
            json!({
                "region": "",
                "amiDistributionConfiguration": "",
                "containerDistributionConfiguration": "",
                "licenseConfigurationArns": "",
                "launchTemplateConfigurations": "",
                "s3ExportConfiguration": "",
                "fastLaunchConfigurations": ""
            })
        ),
        "tags": json!({}),
        "clientToken": ""
    });

    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}}/CreateDistributionConfiguration \
  --header 'content-type: application/json' \
  --data '{
  "name": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "tags": {},
  "clientToken": ""
}'
echo '{
  "name": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "tags": {},
  "clientToken": ""
}' |  \
  http PUT {{baseUrl}}/CreateDistributionConfiguration \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": "",\n  "description": "",\n  "distributions": [\n    {\n      "region": "",\n      "amiDistributionConfiguration": "",\n      "containerDistributionConfiguration": "",\n      "licenseConfigurationArns": "",\n      "launchTemplateConfigurations": "",\n      "s3ExportConfiguration": "",\n      "fastLaunchConfigurations": ""\n    }\n  ],\n  "tags": {},\n  "clientToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/CreateDistributionConfiguration
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "name": "",
  "description": "",
  "distributions": [
    [
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    ]
  ],
  "tags": [],
  "clientToken": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/CreateDistributionConfiguration")! 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 CreateImage
{{baseUrl}}/CreateImage
BODY json

{
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "distributionConfigurationArn": "",
  "infrastructureConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}");

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

(client/put "{{baseUrl}}/CreateImage" {:content-type :json
                                                       :form-params {:imageRecipeArn ""
                                                                     :containerRecipeArn ""
                                                                     :distributionConfigurationArn ""
                                                                     :infrastructureConfigurationArn ""
                                                                     :imageTestsConfiguration {:imageTestsEnabled ""
                                                                                               :timeoutMinutes ""}
                                                                     :enhancedImageMetadataEnabled false
                                                                     :tags {}
                                                                     :clientToken ""
                                                                     :imageScanningConfiguration {:imageScanningEnabled ""
                                                                                                  :ecrConfiguration ""}}})
require "http/client"

url = "{{baseUrl}}/CreateImage"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/CreateImage"),
    Content = new StringContent("{\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/CreateImage");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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/CreateImage HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 396

{
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "distributionConfigurationArn": "",
  "infrastructureConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/CreateImage")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/CreateImage"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/CreateImage")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/CreateImage")
  .header("content-type", "application/json")
  .body("{\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  imageRecipeArn: '',
  containerRecipeArn: '',
  distributionConfigurationArn: '',
  infrastructureConfigurationArn: '',
  imageTestsConfiguration: {
    imageTestsEnabled: '',
    timeoutMinutes: ''
  },
  enhancedImageMetadataEnabled: false,
  tags: {},
  clientToken: '',
  imageScanningConfiguration: {
    imageScanningEnabled: '',
    ecrConfiguration: ''
  }
});

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateImage',
  headers: {'content-type': 'application/json'},
  data: {
    imageRecipeArn: '',
    containerRecipeArn: '',
    distributionConfigurationArn: '',
    infrastructureConfigurationArn: '',
    imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
    enhancedImageMetadataEnabled: false,
    tags: {},
    clientToken: '',
    imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/CreateImage';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"imageRecipeArn":"","containerRecipeArn":"","distributionConfigurationArn":"","infrastructureConfigurationArn":"","imageTestsConfiguration":{"imageTestsEnabled":"","timeoutMinutes":""},"enhancedImageMetadataEnabled":false,"tags":{},"clientToken":"","imageScanningConfiguration":{"imageScanningEnabled":"","ecrConfiguration":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/CreateImage',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "imageRecipeArn": "",\n  "containerRecipeArn": "",\n  "distributionConfigurationArn": "",\n  "infrastructureConfigurationArn": "",\n  "imageTestsConfiguration": {\n    "imageTestsEnabled": "",\n    "timeoutMinutes": ""\n  },\n  "enhancedImageMetadataEnabled": false,\n  "tags": {},\n  "clientToken": "",\n  "imageScanningConfiguration": {\n    "imageScanningEnabled": "",\n    "ecrConfiguration": ""\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  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/CreateImage")
  .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/CreateImage',
  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({
  imageRecipeArn: '',
  containerRecipeArn: '',
  distributionConfigurationArn: '',
  infrastructureConfigurationArn: '',
  imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
  enhancedImageMetadataEnabled: false,
  tags: {},
  clientToken: '',
  imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateImage',
  headers: {'content-type': 'application/json'},
  body: {
    imageRecipeArn: '',
    containerRecipeArn: '',
    distributionConfigurationArn: '',
    infrastructureConfigurationArn: '',
    imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
    enhancedImageMetadataEnabled: false,
    tags: {},
    clientToken: '',
    imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
  },
  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}}/CreateImage');

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

req.type('json');
req.send({
  imageRecipeArn: '',
  containerRecipeArn: '',
  distributionConfigurationArn: '',
  infrastructureConfigurationArn: '',
  imageTestsConfiguration: {
    imageTestsEnabled: '',
    timeoutMinutes: ''
  },
  enhancedImageMetadataEnabled: false,
  tags: {},
  clientToken: '',
  imageScanningConfiguration: {
    imageScanningEnabled: '',
    ecrConfiguration: ''
  }
});

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}}/CreateImage',
  headers: {'content-type': 'application/json'},
  data: {
    imageRecipeArn: '',
    containerRecipeArn: '',
    distributionConfigurationArn: '',
    infrastructureConfigurationArn: '',
    imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
    enhancedImageMetadataEnabled: false,
    tags: {},
    clientToken: '',
    imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
  }
};

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

const url = '{{baseUrl}}/CreateImage';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"imageRecipeArn":"","containerRecipeArn":"","distributionConfigurationArn":"","infrastructureConfigurationArn":"","imageTestsConfiguration":{"imageTestsEnabled":"","timeoutMinutes":""},"enhancedImageMetadataEnabled":false,"tags":{},"clientToken":"","imageScanningConfiguration":{"imageScanningEnabled":"","ecrConfiguration":""}}'
};

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 = @{ @"imageRecipeArn": @"",
                              @"containerRecipeArn": @"",
                              @"distributionConfigurationArn": @"",
                              @"infrastructureConfigurationArn": @"",
                              @"imageTestsConfiguration": @{ @"imageTestsEnabled": @"", @"timeoutMinutes": @"" },
                              @"enhancedImageMetadataEnabled": @NO,
                              @"tags": @{  },
                              @"clientToken": @"",
                              @"imageScanningConfiguration": @{ @"imageScanningEnabled": @"", @"ecrConfiguration": @"" } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/CreateImage"]
                                                       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}}/CreateImage" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/CreateImage",
  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([
    'imageRecipeArn' => '',
    'containerRecipeArn' => '',
    'distributionConfigurationArn' => '',
    'infrastructureConfigurationArn' => '',
    'imageTestsConfiguration' => [
        'imageTestsEnabled' => '',
        'timeoutMinutes' => ''
    ],
    'enhancedImageMetadataEnabled' => null,
    'tags' => [
        
    ],
    'clientToken' => '',
    'imageScanningConfiguration' => [
        'imageScanningEnabled' => '',
        'ecrConfiguration' => ''
    ]
  ]),
  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}}/CreateImage', [
  'body' => '{
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "distributionConfigurationArn": "",
  "infrastructureConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'imageRecipeArn' => '',
  'containerRecipeArn' => '',
  'distributionConfigurationArn' => '',
  'infrastructureConfigurationArn' => '',
  'imageTestsConfiguration' => [
    'imageTestsEnabled' => '',
    'timeoutMinutes' => ''
  ],
  'enhancedImageMetadataEnabled' => null,
  'tags' => [
    
  ],
  'clientToken' => '',
  'imageScanningConfiguration' => [
    'imageScanningEnabled' => '',
    'ecrConfiguration' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'imageRecipeArn' => '',
  'containerRecipeArn' => '',
  'distributionConfigurationArn' => '',
  'infrastructureConfigurationArn' => '',
  'imageTestsConfiguration' => [
    'imageTestsEnabled' => '',
    'timeoutMinutes' => ''
  ],
  'enhancedImageMetadataEnabled' => null,
  'tags' => [
    
  ],
  'clientToken' => '',
  'imageScanningConfiguration' => [
    'imageScanningEnabled' => '',
    'ecrConfiguration' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/CreateImage');
$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}}/CreateImage' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "distributionConfigurationArn": "",
  "infrastructureConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/CreateImage' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "distributionConfigurationArn": "",
  "infrastructureConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}'
import http.client

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

payload = "{\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}"

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

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

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

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

url = "{{baseUrl}}/CreateImage"

payload = {
    "imageRecipeArn": "",
    "containerRecipeArn": "",
    "distributionConfigurationArn": "",
    "infrastructureConfigurationArn": "",
    "imageTestsConfiguration": {
        "imageTestsEnabled": "",
        "timeoutMinutes": ""
    },
    "enhancedImageMetadataEnabled": False,
    "tags": {},
    "clientToken": "",
    "imageScanningConfiguration": {
        "imageScanningEnabled": "",
        "ecrConfiguration": ""
    }
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/CreateImage")

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  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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/CreateImage') do |req|
  req.body = "{\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/CreateImage";

    let payload = json!({
        "imageRecipeArn": "",
        "containerRecipeArn": "",
        "distributionConfigurationArn": "",
        "infrastructureConfigurationArn": "",
        "imageTestsConfiguration": json!({
            "imageTestsEnabled": "",
            "timeoutMinutes": ""
        }),
        "enhancedImageMetadataEnabled": false,
        "tags": json!({}),
        "clientToken": "",
        "imageScanningConfiguration": json!({
            "imageScanningEnabled": "",
            "ecrConfiguration": ""
        })
    });

    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}}/CreateImage \
  --header 'content-type: application/json' \
  --data '{
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "distributionConfigurationArn": "",
  "infrastructureConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}'
echo '{
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "distributionConfigurationArn": "",
  "infrastructureConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}' |  \
  http PUT {{baseUrl}}/CreateImage \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "imageRecipeArn": "",\n  "containerRecipeArn": "",\n  "distributionConfigurationArn": "",\n  "infrastructureConfigurationArn": "",\n  "imageTestsConfiguration": {\n    "imageTestsEnabled": "",\n    "timeoutMinutes": ""\n  },\n  "enhancedImageMetadataEnabled": false,\n  "tags": {},\n  "clientToken": "",\n  "imageScanningConfiguration": {\n    "imageScanningEnabled": "",\n    "ecrConfiguration": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/CreateImage
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "distributionConfigurationArn": "",
  "infrastructureConfigurationArn": "",
  "imageTestsConfiguration": [
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  ],
  "enhancedImageMetadataEnabled": false,
  "tags": [],
  "clientToken": "",
  "imageScanningConfiguration": [
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  ]
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/CreateImage")! 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 CreateImagePipeline
{{baseUrl}}/CreateImagePipeline
BODY json

{
  "name": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}");

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

(client/put "{{baseUrl}}/CreateImagePipeline" {:content-type :json
                                                               :form-params {:name ""
                                                                             :description ""
                                                                             :imageRecipeArn ""
                                                                             :containerRecipeArn ""
                                                                             :infrastructureConfigurationArn ""
                                                                             :distributionConfigurationArn ""
                                                                             :imageTestsConfiguration {:imageTestsEnabled ""
                                                                                                       :timeoutMinutes ""}
                                                                             :enhancedImageMetadataEnabled false
                                                                             :schedule {:scheduleExpression ""
                                                                                        :timezone ""
                                                                                        :pipelineExecutionStartCondition ""}
                                                                             :status ""
                                                                             :tags {}
                                                                             :clientToken ""
                                                                             :imageScanningConfiguration {:imageScanningEnabled ""
                                                                                                          :ecrConfiguration ""}}})
require "http/client"

url = "{{baseUrl}}/CreateImagePipeline"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/CreateImagePipeline"),
    Content = new StringContent("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/CreateImagePipeline");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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/CreateImagePipeline HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 560

{
  "name": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/CreateImagePipeline")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/CreateImagePipeline"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/CreateImagePipeline")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/CreateImagePipeline")
  .header("content-type", "application/json")
  .body("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  name: '',
  description: '',
  imageRecipeArn: '',
  containerRecipeArn: '',
  infrastructureConfigurationArn: '',
  distributionConfigurationArn: '',
  imageTestsConfiguration: {
    imageTestsEnabled: '',
    timeoutMinutes: ''
  },
  enhancedImageMetadataEnabled: false,
  schedule: {
    scheduleExpression: '',
    timezone: '',
    pipelineExecutionStartCondition: ''
  },
  status: '',
  tags: {},
  clientToken: '',
  imageScanningConfiguration: {
    imageScanningEnabled: '',
    ecrConfiguration: ''
  }
});

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateImagePipeline',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    description: '',
    imageRecipeArn: '',
    containerRecipeArn: '',
    infrastructureConfigurationArn: '',
    distributionConfigurationArn: '',
    imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
    enhancedImageMetadataEnabled: false,
    schedule: {scheduleExpression: '', timezone: '', pipelineExecutionStartCondition: ''},
    status: '',
    tags: {},
    clientToken: '',
    imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/CreateImagePipeline';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","description":"","imageRecipeArn":"","containerRecipeArn":"","infrastructureConfigurationArn":"","distributionConfigurationArn":"","imageTestsConfiguration":{"imageTestsEnabled":"","timeoutMinutes":""},"enhancedImageMetadataEnabled":false,"schedule":{"scheduleExpression":"","timezone":"","pipelineExecutionStartCondition":""},"status":"","tags":{},"clientToken":"","imageScanningConfiguration":{"imageScanningEnabled":"","ecrConfiguration":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/CreateImagePipeline',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name": "",\n  "description": "",\n  "imageRecipeArn": "",\n  "containerRecipeArn": "",\n  "infrastructureConfigurationArn": "",\n  "distributionConfigurationArn": "",\n  "imageTestsConfiguration": {\n    "imageTestsEnabled": "",\n    "timeoutMinutes": ""\n  },\n  "enhancedImageMetadataEnabled": false,\n  "schedule": {\n    "scheduleExpression": "",\n    "timezone": "",\n    "pipelineExecutionStartCondition": ""\n  },\n  "status": "",\n  "tags": {},\n  "clientToken": "",\n  "imageScanningConfiguration": {\n    "imageScanningEnabled": "",\n    "ecrConfiguration": ""\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  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/CreateImagePipeline")
  .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/CreateImagePipeline',
  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({
  name: '',
  description: '',
  imageRecipeArn: '',
  containerRecipeArn: '',
  infrastructureConfigurationArn: '',
  distributionConfigurationArn: '',
  imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
  enhancedImageMetadataEnabled: false,
  schedule: {scheduleExpression: '', timezone: '', pipelineExecutionStartCondition: ''},
  status: '',
  tags: {},
  clientToken: '',
  imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateImagePipeline',
  headers: {'content-type': 'application/json'},
  body: {
    name: '',
    description: '',
    imageRecipeArn: '',
    containerRecipeArn: '',
    infrastructureConfigurationArn: '',
    distributionConfigurationArn: '',
    imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
    enhancedImageMetadataEnabled: false,
    schedule: {scheduleExpression: '', timezone: '', pipelineExecutionStartCondition: ''},
    status: '',
    tags: {},
    clientToken: '',
    imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
  },
  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}}/CreateImagePipeline');

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

req.type('json');
req.send({
  name: '',
  description: '',
  imageRecipeArn: '',
  containerRecipeArn: '',
  infrastructureConfigurationArn: '',
  distributionConfigurationArn: '',
  imageTestsConfiguration: {
    imageTestsEnabled: '',
    timeoutMinutes: ''
  },
  enhancedImageMetadataEnabled: false,
  schedule: {
    scheduleExpression: '',
    timezone: '',
    pipelineExecutionStartCondition: ''
  },
  status: '',
  tags: {},
  clientToken: '',
  imageScanningConfiguration: {
    imageScanningEnabled: '',
    ecrConfiguration: ''
  }
});

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}}/CreateImagePipeline',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    description: '',
    imageRecipeArn: '',
    containerRecipeArn: '',
    infrastructureConfigurationArn: '',
    distributionConfigurationArn: '',
    imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
    enhancedImageMetadataEnabled: false,
    schedule: {scheduleExpression: '', timezone: '', pipelineExecutionStartCondition: ''},
    status: '',
    tags: {},
    clientToken: '',
    imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
  }
};

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

const url = '{{baseUrl}}/CreateImagePipeline';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","description":"","imageRecipeArn":"","containerRecipeArn":"","infrastructureConfigurationArn":"","distributionConfigurationArn":"","imageTestsConfiguration":{"imageTestsEnabled":"","timeoutMinutes":""},"enhancedImageMetadataEnabled":false,"schedule":{"scheduleExpression":"","timezone":"","pipelineExecutionStartCondition":""},"status":"","tags":{},"clientToken":"","imageScanningConfiguration":{"imageScanningEnabled":"","ecrConfiguration":""}}'
};

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 = @{ @"name": @"",
                              @"description": @"",
                              @"imageRecipeArn": @"",
                              @"containerRecipeArn": @"",
                              @"infrastructureConfigurationArn": @"",
                              @"distributionConfigurationArn": @"",
                              @"imageTestsConfiguration": @{ @"imageTestsEnabled": @"", @"timeoutMinutes": @"" },
                              @"enhancedImageMetadataEnabled": @NO,
                              @"schedule": @{ @"scheduleExpression": @"", @"timezone": @"", @"pipelineExecutionStartCondition": @"" },
                              @"status": @"",
                              @"tags": @{  },
                              @"clientToken": @"",
                              @"imageScanningConfiguration": @{ @"imageScanningEnabled": @"", @"ecrConfiguration": @"" } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/CreateImagePipeline"]
                                                       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}}/CreateImagePipeline" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/CreateImagePipeline",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'name' => '',
    'description' => '',
    'imageRecipeArn' => '',
    'containerRecipeArn' => '',
    'infrastructureConfigurationArn' => '',
    'distributionConfigurationArn' => '',
    'imageTestsConfiguration' => [
        'imageTestsEnabled' => '',
        'timeoutMinutes' => ''
    ],
    'enhancedImageMetadataEnabled' => null,
    'schedule' => [
        'scheduleExpression' => '',
        'timezone' => '',
        'pipelineExecutionStartCondition' => ''
    ],
    'status' => '',
    'tags' => [
        
    ],
    'clientToken' => '',
    'imageScanningConfiguration' => [
        'imageScanningEnabled' => '',
        'ecrConfiguration' => ''
    ]
  ]),
  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}}/CreateImagePipeline', [
  'body' => '{
  "name": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name' => '',
  'description' => '',
  'imageRecipeArn' => '',
  'containerRecipeArn' => '',
  'infrastructureConfigurationArn' => '',
  'distributionConfigurationArn' => '',
  'imageTestsConfiguration' => [
    'imageTestsEnabled' => '',
    'timeoutMinutes' => ''
  ],
  'enhancedImageMetadataEnabled' => null,
  'schedule' => [
    'scheduleExpression' => '',
    'timezone' => '',
    'pipelineExecutionStartCondition' => ''
  ],
  'status' => '',
  'tags' => [
    
  ],
  'clientToken' => '',
  'imageScanningConfiguration' => [
    'imageScanningEnabled' => '',
    'ecrConfiguration' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name' => '',
  'description' => '',
  'imageRecipeArn' => '',
  'containerRecipeArn' => '',
  'infrastructureConfigurationArn' => '',
  'distributionConfigurationArn' => '',
  'imageTestsConfiguration' => [
    'imageTestsEnabled' => '',
    'timeoutMinutes' => ''
  ],
  'enhancedImageMetadataEnabled' => null,
  'schedule' => [
    'scheduleExpression' => '',
    'timezone' => '',
    'pipelineExecutionStartCondition' => ''
  ],
  'status' => '',
  'tags' => [
    
  ],
  'clientToken' => '',
  'imageScanningConfiguration' => [
    'imageScanningEnabled' => '',
    'ecrConfiguration' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/CreateImagePipeline');
$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}}/CreateImagePipeline' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/CreateImagePipeline' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}'
import http.client

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

payload = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}"

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

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

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

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

url = "{{baseUrl}}/CreateImagePipeline"

payload = {
    "name": "",
    "description": "",
    "imageRecipeArn": "",
    "containerRecipeArn": "",
    "infrastructureConfigurationArn": "",
    "distributionConfigurationArn": "",
    "imageTestsConfiguration": {
        "imageTestsEnabled": "",
        "timeoutMinutes": ""
    },
    "enhancedImageMetadataEnabled": False,
    "schedule": {
        "scheduleExpression": "",
        "timezone": "",
        "pipelineExecutionStartCondition": ""
    },
    "status": "",
    "tags": {},
    "clientToken": "",
    "imageScanningConfiguration": {
        "imageScanningEnabled": "",
        "ecrConfiguration": ""
    }
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/CreateImagePipeline")

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  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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/CreateImagePipeline') do |req|
  req.body = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/CreateImagePipeline";

    let payload = json!({
        "name": "",
        "description": "",
        "imageRecipeArn": "",
        "containerRecipeArn": "",
        "infrastructureConfigurationArn": "",
        "distributionConfigurationArn": "",
        "imageTestsConfiguration": json!({
            "imageTestsEnabled": "",
            "timeoutMinutes": ""
        }),
        "enhancedImageMetadataEnabled": false,
        "schedule": json!({
            "scheduleExpression": "",
            "timezone": "",
            "pipelineExecutionStartCondition": ""
        }),
        "status": "",
        "tags": json!({}),
        "clientToken": "",
        "imageScanningConfiguration": json!({
            "imageScanningEnabled": "",
            "ecrConfiguration": ""
        })
    });

    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}}/CreateImagePipeline \
  --header 'content-type: application/json' \
  --data '{
  "name": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}'
echo '{
  "name": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "tags": {},
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}' |  \
  http PUT {{baseUrl}}/CreateImagePipeline \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": "",\n  "description": "",\n  "imageRecipeArn": "",\n  "containerRecipeArn": "",\n  "infrastructureConfigurationArn": "",\n  "distributionConfigurationArn": "",\n  "imageTestsConfiguration": {\n    "imageTestsEnabled": "",\n    "timeoutMinutes": ""\n  },\n  "enhancedImageMetadataEnabled": false,\n  "schedule": {\n    "scheduleExpression": "",\n    "timezone": "",\n    "pipelineExecutionStartCondition": ""\n  },\n  "status": "",\n  "tags": {},\n  "clientToken": "",\n  "imageScanningConfiguration": {\n    "imageScanningEnabled": "",\n    "ecrConfiguration": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/CreateImagePipeline
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "name": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": [
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  ],
  "enhancedImageMetadataEnabled": false,
  "schedule": [
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  ],
  "status": "",
  "tags": [],
  "clientToken": "",
  "imageScanningConfiguration": [
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  ]
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/CreateImagePipeline")! 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 CreateImageRecipe
{{baseUrl}}/CreateImageRecipe
BODY json

{
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "parentImage": "",
  "blockDeviceMappings": [
    {
      "deviceName": "",
      "ebs": "",
      "virtualName": "",
      "noDevice": ""
    }
  ],
  "tags": {},
  "workingDirectory": "",
  "additionalInstanceConfiguration": {
    "systemsManagerAgent": "",
    "userDataOverride": ""
  },
  "clientToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\n}");

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

(client/put "{{baseUrl}}/CreateImageRecipe" {:content-type :json
                                                             :form-params {:name ""
                                                                           :description ""
                                                                           :semanticVersion ""
                                                                           :components [{:componentArn ""
                                                                                         :parameters ""}]
                                                                           :parentImage ""
                                                                           :blockDeviceMappings [{:deviceName ""
                                                                                                  :ebs ""
                                                                                                  :virtualName ""
                                                                                                  :noDevice ""}]
                                                                           :tags {}
                                                                           :workingDirectory ""
                                                                           :additionalInstanceConfiguration {:systemsManagerAgent ""
                                                                                                             :userDataOverride ""}
                                                                           :clientToken ""}})
require "http/client"

url = "{{baseUrl}}/CreateImageRecipe"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\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}}/CreateImageRecipe"),
    Content = new StringContent("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/CreateImageRecipe");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\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/CreateImageRecipe HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 461

{
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "parentImage": "",
  "blockDeviceMappings": [
    {
      "deviceName": "",
      "ebs": "",
      "virtualName": "",
      "noDevice": ""
    }
  ],
  "tags": {},
  "workingDirectory": "",
  "additionalInstanceConfiguration": {
    "systemsManagerAgent": "",
    "userDataOverride": ""
  },
  "clientToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/CreateImageRecipe")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/CreateImageRecipe"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/CreateImageRecipe")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/CreateImageRecipe")
  .header("content-type", "application/json")
  .body("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  name: '',
  description: '',
  semanticVersion: '',
  components: [
    {
      componentArn: '',
      parameters: ''
    }
  ],
  parentImage: '',
  blockDeviceMappings: [
    {
      deviceName: '',
      ebs: '',
      virtualName: '',
      noDevice: ''
    }
  ],
  tags: {},
  workingDirectory: '',
  additionalInstanceConfiguration: {
    systemsManagerAgent: '',
    userDataOverride: ''
  },
  clientToken: ''
});

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateImageRecipe',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    description: '',
    semanticVersion: '',
    components: [{componentArn: '', parameters: ''}],
    parentImage: '',
    blockDeviceMappings: [{deviceName: '', ebs: '', virtualName: '', noDevice: ''}],
    tags: {},
    workingDirectory: '',
    additionalInstanceConfiguration: {systemsManagerAgent: '', userDataOverride: ''},
    clientToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/CreateImageRecipe';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","description":"","semanticVersion":"","components":[{"componentArn":"","parameters":""}],"parentImage":"","blockDeviceMappings":[{"deviceName":"","ebs":"","virtualName":"","noDevice":""}],"tags":{},"workingDirectory":"","additionalInstanceConfiguration":{"systemsManagerAgent":"","userDataOverride":""},"clientToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/CreateImageRecipe',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name": "",\n  "description": "",\n  "semanticVersion": "",\n  "components": [\n    {\n      "componentArn": "",\n      "parameters": ""\n    }\n  ],\n  "parentImage": "",\n  "blockDeviceMappings": [\n    {\n      "deviceName": "",\n      "ebs": "",\n      "virtualName": "",\n      "noDevice": ""\n    }\n  ],\n  "tags": {},\n  "workingDirectory": "",\n  "additionalInstanceConfiguration": {\n    "systemsManagerAgent": "",\n    "userDataOverride": ""\n  },\n  "clientToken": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/CreateImageRecipe")
  .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/CreateImageRecipe',
  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({
  name: '',
  description: '',
  semanticVersion: '',
  components: [{componentArn: '', parameters: ''}],
  parentImage: '',
  blockDeviceMappings: [{deviceName: '', ebs: '', virtualName: '', noDevice: ''}],
  tags: {},
  workingDirectory: '',
  additionalInstanceConfiguration: {systemsManagerAgent: '', userDataOverride: ''},
  clientToken: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateImageRecipe',
  headers: {'content-type': 'application/json'},
  body: {
    name: '',
    description: '',
    semanticVersion: '',
    components: [{componentArn: '', parameters: ''}],
    parentImage: '',
    blockDeviceMappings: [{deviceName: '', ebs: '', virtualName: '', noDevice: ''}],
    tags: {},
    workingDirectory: '',
    additionalInstanceConfiguration: {systemsManagerAgent: '', userDataOverride: ''},
    clientToken: ''
  },
  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}}/CreateImageRecipe');

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

req.type('json');
req.send({
  name: '',
  description: '',
  semanticVersion: '',
  components: [
    {
      componentArn: '',
      parameters: ''
    }
  ],
  parentImage: '',
  blockDeviceMappings: [
    {
      deviceName: '',
      ebs: '',
      virtualName: '',
      noDevice: ''
    }
  ],
  tags: {},
  workingDirectory: '',
  additionalInstanceConfiguration: {
    systemsManagerAgent: '',
    userDataOverride: ''
  },
  clientToken: ''
});

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}}/CreateImageRecipe',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    description: '',
    semanticVersion: '',
    components: [{componentArn: '', parameters: ''}],
    parentImage: '',
    blockDeviceMappings: [{deviceName: '', ebs: '', virtualName: '', noDevice: ''}],
    tags: {},
    workingDirectory: '',
    additionalInstanceConfiguration: {systemsManagerAgent: '', userDataOverride: ''},
    clientToken: ''
  }
};

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

const url = '{{baseUrl}}/CreateImageRecipe';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","description":"","semanticVersion":"","components":[{"componentArn":"","parameters":""}],"parentImage":"","blockDeviceMappings":[{"deviceName":"","ebs":"","virtualName":"","noDevice":""}],"tags":{},"workingDirectory":"","additionalInstanceConfiguration":{"systemsManagerAgent":"","userDataOverride":""},"clientToken":""}'
};

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 = @{ @"name": @"",
                              @"description": @"",
                              @"semanticVersion": @"",
                              @"components": @[ @{ @"componentArn": @"", @"parameters": @"" } ],
                              @"parentImage": @"",
                              @"blockDeviceMappings": @[ @{ @"deviceName": @"", @"ebs": @"", @"virtualName": @"", @"noDevice": @"" } ],
                              @"tags": @{  },
                              @"workingDirectory": @"",
                              @"additionalInstanceConfiguration": @{ @"systemsManagerAgent": @"", @"userDataOverride": @"" },
                              @"clientToken": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/CreateImageRecipe"]
                                                       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}}/CreateImageRecipe" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/CreateImageRecipe",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'name' => '',
    'description' => '',
    'semanticVersion' => '',
    'components' => [
        [
                'componentArn' => '',
                'parameters' => ''
        ]
    ],
    'parentImage' => '',
    'blockDeviceMappings' => [
        [
                'deviceName' => '',
                'ebs' => '',
                'virtualName' => '',
                'noDevice' => ''
        ]
    ],
    'tags' => [
        
    ],
    'workingDirectory' => '',
    'additionalInstanceConfiguration' => [
        'systemsManagerAgent' => '',
        'userDataOverride' => ''
    ],
    'clientToken' => ''
  ]),
  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}}/CreateImageRecipe', [
  'body' => '{
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "parentImage": "",
  "blockDeviceMappings": [
    {
      "deviceName": "",
      "ebs": "",
      "virtualName": "",
      "noDevice": ""
    }
  ],
  "tags": {},
  "workingDirectory": "",
  "additionalInstanceConfiguration": {
    "systemsManagerAgent": "",
    "userDataOverride": ""
  },
  "clientToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name' => '',
  'description' => '',
  'semanticVersion' => '',
  'components' => [
    [
        'componentArn' => '',
        'parameters' => ''
    ]
  ],
  'parentImage' => '',
  'blockDeviceMappings' => [
    [
        'deviceName' => '',
        'ebs' => '',
        'virtualName' => '',
        'noDevice' => ''
    ]
  ],
  'tags' => [
    
  ],
  'workingDirectory' => '',
  'additionalInstanceConfiguration' => [
    'systemsManagerAgent' => '',
    'userDataOverride' => ''
  ],
  'clientToken' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name' => '',
  'description' => '',
  'semanticVersion' => '',
  'components' => [
    [
        'componentArn' => '',
        'parameters' => ''
    ]
  ],
  'parentImage' => '',
  'blockDeviceMappings' => [
    [
        'deviceName' => '',
        'ebs' => '',
        'virtualName' => '',
        'noDevice' => ''
    ]
  ],
  'tags' => [
    
  ],
  'workingDirectory' => '',
  'additionalInstanceConfiguration' => [
    'systemsManagerAgent' => '',
    'userDataOverride' => ''
  ],
  'clientToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/CreateImageRecipe');
$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}}/CreateImageRecipe' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "parentImage": "",
  "blockDeviceMappings": [
    {
      "deviceName": "",
      "ebs": "",
      "virtualName": "",
      "noDevice": ""
    }
  ],
  "tags": {},
  "workingDirectory": "",
  "additionalInstanceConfiguration": {
    "systemsManagerAgent": "",
    "userDataOverride": ""
  },
  "clientToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/CreateImageRecipe' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "parentImage": "",
  "blockDeviceMappings": [
    {
      "deviceName": "",
      "ebs": "",
      "virtualName": "",
      "noDevice": ""
    }
  ],
  "tags": {},
  "workingDirectory": "",
  "additionalInstanceConfiguration": {
    "systemsManagerAgent": "",
    "userDataOverride": ""
  },
  "clientToken": ""
}'
import http.client

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

payload = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\n}"

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

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

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

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

url = "{{baseUrl}}/CreateImageRecipe"

payload = {
    "name": "",
    "description": "",
    "semanticVersion": "",
    "components": [
        {
            "componentArn": "",
            "parameters": ""
        }
    ],
    "parentImage": "",
    "blockDeviceMappings": [
        {
            "deviceName": "",
            "ebs": "",
            "virtualName": "",
            "noDevice": ""
        }
    ],
    "tags": {},
    "workingDirectory": "",
    "additionalInstanceConfiguration": {
        "systemsManagerAgent": "",
        "userDataOverride": ""
    },
    "clientToken": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\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}}/CreateImageRecipe")

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  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\n}"

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/CreateImageRecipe') do |req|
  req.body = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"semanticVersion\": \"\",\n  \"components\": [\n    {\n      \"componentArn\": \"\",\n      \"parameters\": \"\"\n    }\n  ],\n  \"parentImage\": \"\",\n  \"blockDeviceMappings\": [\n    {\n      \"deviceName\": \"\",\n      \"ebs\": \"\",\n      \"virtualName\": \"\",\n      \"noDevice\": \"\"\n    }\n  ],\n  \"tags\": {},\n  \"workingDirectory\": \"\",\n  \"additionalInstanceConfiguration\": {\n    \"systemsManagerAgent\": \"\",\n    \"userDataOverride\": \"\"\n  },\n  \"clientToken\": \"\"\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}}/CreateImageRecipe";

    let payload = json!({
        "name": "",
        "description": "",
        "semanticVersion": "",
        "components": (
            json!({
                "componentArn": "",
                "parameters": ""
            })
        ),
        "parentImage": "",
        "blockDeviceMappings": (
            json!({
                "deviceName": "",
                "ebs": "",
                "virtualName": "",
                "noDevice": ""
            })
        ),
        "tags": json!({}),
        "workingDirectory": "",
        "additionalInstanceConfiguration": json!({
            "systemsManagerAgent": "",
            "userDataOverride": ""
        }),
        "clientToken": ""
    });

    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}}/CreateImageRecipe \
  --header 'content-type: application/json' \
  --data '{
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "parentImage": "",
  "blockDeviceMappings": [
    {
      "deviceName": "",
      "ebs": "",
      "virtualName": "",
      "noDevice": ""
    }
  ],
  "tags": {},
  "workingDirectory": "",
  "additionalInstanceConfiguration": {
    "systemsManagerAgent": "",
    "userDataOverride": ""
  },
  "clientToken": ""
}'
echo '{
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    {
      "componentArn": "",
      "parameters": ""
    }
  ],
  "parentImage": "",
  "blockDeviceMappings": [
    {
      "deviceName": "",
      "ebs": "",
      "virtualName": "",
      "noDevice": ""
    }
  ],
  "tags": {},
  "workingDirectory": "",
  "additionalInstanceConfiguration": {
    "systemsManagerAgent": "",
    "userDataOverride": ""
  },
  "clientToken": ""
}' |  \
  http PUT {{baseUrl}}/CreateImageRecipe \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": "",\n  "description": "",\n  "semanticVersion": "",\n  "components": [\n    {\n      "componentArn": "",\n      "parameters": ""\n    }\n  ],\n  "parentImage": "",\n  "blockDeviceMappings": [\n    {\n      "deviceName": "",\n      "ebs": "",\n      "virtualName": "",\n      "noDevice": ""\n    }\n  ],\n  "tags": {},\n  "workingDirectory": "",\n  "additionalInstanceConfiguration": {\n    "systemsManagerAgent": "",\n    "userDataOverride": ""\n  },\n  "clientToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/CreateImageRecipe
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "name": "",
  "description": "",
  "semanticVersion": "",
  "components": [
    [
      "componentArn": "",
      "parameters": ""
    ]
  ],
  "parentImage": "",
  "blockDeviceMappings": [
    [
      "deviceName": "",
      "ebs": "",
      "virtualName": "",
      "noDevice": ""
    ]
  ],
  "tags": [],
  "workingDirectory": "",
  "additionalInstanceConfiguration": [
    "systemsManagerAgent": "",
    "userDataOverride": ""
  ],
  "clientToken": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/CreateImageRecipe")! 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 CreateInfrastructureConfiguration
{{baseUrl}}/CreateInfrastructureConfiguration
BODY json

{
  "name": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  },
  "tags": {},
  "clientToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\n}");

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

(client/put "{{baseUrl}}/CreateInfrastructureConfiguration" {:content-type :json
                                                                             :form-params {:name ""
                                                                                           :description ""
                                                                                           :instanceTypes []
                                                                                           :instanceProfileName ""
                                                                                           :securityGroupIds []
                                                                                           :subnetId ""
                                                                                           :logging {:s3Logs ""}
                                                                                           :keyPair ""
                                                                                           :terminateInstanceOnFailure false
                                                                                           :snsTopicArn ""
                                                                                           :resourceTags {}
                                                                                           :instanceMetadataOptions {:httpTokens ""
                                                                                                                     :httpPutResponseHopLimit ""}
                                                                                           :tags {}
                                                                                           :clientToken ""}})
require "http/client"

url = "{{baseUrl}}/CreateInfrastructureConfiguration"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/CreateInfrastructureConfiguration"),
    Content = new StringContent("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/CreateInfrastructureConfiguration");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\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/CreateInfrastructureConfiguration HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 396

{
  "name": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  },
  "tags": {},
  "clientToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/CreateInfrastructureConfiguration")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/CreateInfrastructureConfiguration"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/CreateInfrastructureConfiguration")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/CreateInfrastructureConfiguration")
  .header("content-type", "application/json")
  .body("{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  name: '',
  description: '',
  instanceTypes: [],
  instanceProfileName: '',
  securityGroupIds: [],
  subnetId: '',
  logging: {
    s3Logs: ''
  },
  keyPair: '',
  terminateInstanceOnFailure: false,
  snsTopicArn: '',
  resourceTags: {},
  instanceMetadataOptions: {
    httpTokens: '',
    httpPutResponseHopLimit: ''
  },
  tags: {},
  clientToken: ''
});

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateInfrastructureConfiguration',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    description: '',
    instanceTypes: [],
    instanceProfileName: '',
    securityGroupIds: [],
    subnetId: '',
    logging: {s3Logs: ''},
    keyPair: '',
    terminateInstanceOnFailure: false,
    snsTopicArn: '',
    resourceTags: {},
    instanceMetadataOptions: {httpTokens: '', httpPutResponseHopLimit: ''},
    tags: {},
    clientToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/CreateInfrastructureConfiguration';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","description":"","instanceTypes":[],"instanceProfileName":"","securityGroupIds":[],"subnetId":"","logging":{"s3Logs":""},"keyPair":"","terminateInstanceOnFailure":false,"snsTopicArn":"","resourceTags":{},"instanceMetadataOptions":{"httpTokens":"","httpPutResponseHopLimit":""},"tags":{},"clientToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/CreateInfrastructureConfiguration',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name": "",\n  "description": "",\n  "instanceTypes": [],\n  "instanceProfileName": "",\n  "securityGroupIds": [],\n  "subnetId": "",\n  "logging": {\n    "s3Logs": ""\n  },\n  "keyPair": "",\n  "terminateInstanceOnFailure": false,\n  "snsTopicArn": "",\n  "resourceTags": {},\n  "instanceMetadataOptions": {\n    "httpTokens": "",\n    "httpPutResponseHopLimit": ""\n  },\n  "tags": {},\n  "clientToken": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/CreateInfrastructureConfiguration")
  .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/CreateInfrastructureConfiguration',
  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({
  name: '',
  description: '',
  instanceTypes: [],
  instanceProfileName: '',
  securityGroupIds: [],
  subnetId: '',
  logging: {s3Logs: ''},
  keyPair: '',
  terminateInstanceOnFailure: false,
  snsTopicArn: '',
  resourceTags: {},
  instanceMetadataOptions: {httpTokens: '', httpPutResponseHopLimit: ''},
  tags: {},
  clientToken: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/CreateInfrastructureConfiguration',
  headers: {'content-type': 'application/json'},
  body: {
    name: '',
    description: '',
    instanceTypes: [],
    instanceProfileName: '',
    securityGroupIds: [],
    subnetId: '',
    logging: {s3Logs: ''},
    keyPair: '',
    terminateInstanceOnFailure: false,
    snsTopicArn: '',
    resourceTags: {},
    instanceMetadataOptions: {httpTokens: '', httpPutResponseHopLimit: ''},
    tags: {},
    clientToken: ''
  },
  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}}/CreateInfrastructureConfiguration');

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

req.type('json');
req.send({
  name: '',
  description: '',
  instanceTypes: [],
  instanceProfileName: '',
  securityGroupIds: [],
  subnetId: '',
  logging: {
    s3Logs: ''
  },
  keyPair: '',
  terminateInstanceOnFailure: false,
  snsTopicArn: '',
  resourceTags: {},
  instanceMetadataOptions: {
    httpTokens: '',
    httpPutResponseHopLimit: ''
  },
  tags: {},
  clientToken: ''
});

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}}/CreateInfrastructureConfiguration',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    description: '',
    instanceTypes: [],
    instanceProfileName: '',
    securityGroupIds: [],
    subnetId: '',
    logging: {s3Logs: ''},
    keyPair: '',
    terminateInstanceOnFailure: false,
    snsTopicArn: '',
    resourceTags: {},
    instanceMetadataOptions: {httpTokens: '', httpPutResponseHopLimit: ''},
    tags: {},
    clientToken: ''
  }
};

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

const url = '{{baseUrl}}/CreateInfrastructureConfiguration';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","description":"","instanceTypes":[],"instanceProfileName":"","securityGroupIds":[],"subnetId":"","logging":{"s3Logs":""},"keyPair":"","terminateInstanceOnFailure":false,"snsTopicArn":"","resourceTags":{},"instanceMetadataOptions":{"httpTokens":"","httpPutResponseHopLimit":""},"tags":{},"clientToken":""}'
};

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 = @{ @"name": @"",
                              @"description": @"",
                              @"instanceTypes": @[  ],
                              @"instanceProfileName": @"",
                              @"securityGroupIds": @[  ],
                              @"subnetId": @"",
                              @"logging": @{ @"s3Logs": @"" },
                              @"keyPair": @"",
                              @"terminateInstanceOnFailure": @NO,
                              @"snsTopicArn": @"",
                              @"resourceTags": @{  },
                              @"instanceMetadataOptions": @{ @"httpTokens": @"", @"httpPutResponseHopLimit": @"" },
                              @"tags": @{  },
                              @"clientToken": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/CreateInfrastructureConfiguration"]
                                                       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}}/CreateInfrastructureConfiguration" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/CreateInfrastructureConfiguration",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'name' => '',
    'description' => '',
    'instanceTypes' => [
        
    ],
    'instanceProfileName' => '',
    'securityGroupIds' => [
        
    ],
    'subnetId' => '',
    'logging' => [
        's3Logs' => ''
    ],
    'keyPair' => '',
    'terminateInstanceOnFailure' => null,
    'snsTopicArn' => '',
    'resourceTags' => [
        
    ],
    'instanceMetadataOptions' => [
        'httpTokens' => '',
        'httpPutResponseHopLimit' => ''
    ],
    'tags' => [
        
    ],
    'clientToken' => ''
  ]),
  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}}/CreateInfrastructureConfiguration', [
  'body' => '{
  "name": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  },
  "tags": {},
  "clientToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name' => '',
  'description' => '',
  'instanceTypes' => [
    
  ],
  'instanceProfileName' => '',
  'securityGroupIds' => [
    
  ],
  'subnetId' => '',
  'logging' => [
    's3Logs' => ''
  ],
  'keyPair' => '',
  'terminateInstanceOnFailure' => null,
  'snsTopicArn' => '',
  'resourceTags' => [
    
  ],
  'instanceMetadataOptions' => [
    'httpTokens' => '',
    'httpPutResponseHopLimit' => ''
  ],
  'tags' => [
    
  ],
  'clientToken' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name' => '',
  'description' => '',
  'instanceTypes' => [
    
  ],
  'instanceProfileName' => '',
  'securityGroupIds' => [
    
  ],
  'subnetId' => '',
  'logging' => [
    's3Logs' => ''
  ],
  'keyPair' => '',
  'terminateInstanceOnFailure' => null,
  'snsTopicArn' => '',
  'resourceTags' => [
    
  ],
  'instanceMetadataOptions' => [
    'httpTokens' => '',
    'httpPutResponseHopLimit' => ''
  ],
  'tags' => [
    
  ],
  'clientToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/CreateInfrastructureConfiguration');
$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}}/CreateInfrastructureConfiguration' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  },
  "tags": {},
  "clientToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/CreateInfrastructureConfiguration' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  },
  "tags": {},
  "clientToken": ""
}'
import http.client

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

payload = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"

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

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

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

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

url = "{{baseUrl}}/CreateInfrastructureConfiguration"

payload = {
    "name": "",
    "description": "",
    "instanceTypes": [],
    "instanceProfileName": "",
    "securityGroupIds": [],
    "subnetId": "",
    "logging": { "s3Logs": "" },
    "keyPair": "",
    "terminateInstanceOnFailure": False,
    "snsTopicArn": "",
    "resourceTags": {},
    "instanceMetadataOptions": {
        "httpTokens": "",
        "httpPutResponseHopLimit": ""
    },
    "tags": {},
    "clientToken": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/CreateInfrastructureConfiguration")

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  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"

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/CreateInfrastructureConfiguration') do |req|
  req.body = "{\n  \"name\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  },\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/CreateInfrastructureConfiguration";

    let payload = json!({
        "name": "",
        "description": "",
        "instanceTypes": (),
        "instanceProfileName": "",
        "securityGroupIds": (),
        "subnetId": "",
        "logging": json!({"s3Logs": ""}),
        "keyPair": "",
        "terminateInstanceOnFailure": false,
        "snsTopicArn": "",
        "resourceTags": json!({}),
        "instanceMetadataOptions": json!({
            "httpTokens": "",
            "httpPutResponseHopLimit": ""
        }),
        "tags": json!({}),
        "clientToken": ""
    });

    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}}/CreateInfrastructureConfiguration \
  --header 'content-type: application/json' \
  --data '{
  "name": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  },
  "tags": {},
  "clientToken": ""
}'
echo '{
  "name": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  },
  "tags": {},
  "clientToken": ""
}' |  \
  http PUT {{baseUrl}}/CreateInfrastructureConfiguration \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": "",\n  "description": "",\n  "instanceTypes": [],\n  "instanceProfileName": "",\n  "securityGroupIds": [],\n  "subnetId": "",\n  "logging": {\n    "s3Logs": ""\n  },\n  "keyPair": "",\n  "terminateInstanceOnFailure": false,\n  "snsTopicArn": "",\n  "resourceTags": {},\n  "instanceMetadataOptions": {\n    "httpTokens": "",\n    "httpPutResponseHopLimit": ""\n  },\n  "tags": {},\n  "clientToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/CreateInfrastructureConfiguration
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "name": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": ["s3Logs": ""],
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "resourceTags": [],
  "instanceMetadataOptions": [
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  ],
  "tags": [],
  "clientToken": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/CreateInfrastructureConfiguration")! 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 DeleteComponent
{{baseUrl}}/DeleteComponent#componentBuildVersionArn
QUERY PARAMS

componentBuildVersionArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn");

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

(client/delete "{{baseUrl}}/DeleteComponent#componentBuildVersionArn" {:query-params {:componentBuildVersionArn ""}})
require "http/client"

url = "{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn"

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

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

func main() {

	url := "{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn"

	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/DeleteComponent?componentBuildVersionArn= HTTP/1.1
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn")
  .asString();
const 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}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/DeleteComponent#componentBuildVersionArn',
  params: {componentBuildVersionArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn")
  .delete(null)
  .build()

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

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

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

  res.on('data', function (chunk) {
    chunks.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}}/DeleteComponent#componentBuildVersionArn',
  qs: {componentBuildVersionArn: ''}
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/DeleteComponent#componentBuildVersionArn');

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

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}}/DeleteComponent#componentBuildVersionArn',
  params: {componentBuildVersionArn: ''}
};

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

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

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

echo $response->getBody();
setUrl('{{baseUrl}}/DeleteComponent#componentBuildVersionArn');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/DeleteComponent?componentBuildVersionArn=")

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

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

url = "{{baseUrl}}/DeleteComponent#componentBuildVersionArn"

querystring = {"componentBuildVersionArn":""}

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

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

url <- "{{baseUrl}}/DeleteComponent#componentBuildVersionArn"

queryString <- list(componentBuildVersionArn = "")

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

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

url = URI("{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn")

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/DeleteComponent') do |req|
  req.params['componentBuildVersionArn'] = ''
end

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

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

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

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

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

    dbg!(results);
}
curl --request DELETE \
  --url '{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn'
http DELETE '{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn'
wget --quiet \
  --method DELETE \
  --output-document \
  - '{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/DeleteComponent?componentBuildVersionArn=#componentBuildVersionArn")! 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 DeleteContainerRecipe
{{baseUrl}}/DeleteContainerRecipe#containerRecipeArn
QUERY PARAMS

containerRecipeArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn");

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

(client/delete "{{baseUrl}}/DeleteContainerRecipe#containerRecipeArn" {:query-params {:containerRecipeArn ""}})
require "http/client"

url = "{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn"

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

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

func main() {

	url := "{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn"

	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/DeleteContainerRecipe?containerRecipeArn= HTTP/1.1
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn")
  .asString();
const 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}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/DeleteContainerRecipe#containerRecipeArn',
  params: {containerRecipeArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn")
  .delete(null)
  .build()

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

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

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

  res.on('data', function (chunk) {
    chunks.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}}/DeleteContainerRecipe#containerRecipeArn',
  qs: {containerRecipeArn: ''}
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/DeleteContainerRecipe#containerRecipeArn');

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

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}}/DeleteContainerRecipe#containerRecipeArn',
  params: {containerRecipeArn: ''}
};

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

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

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

echo $response->getBody();
setUrl('{{baseUrl}}/DeleteContainerRecipe#containerRecipeArn');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/DeleteContainerRecipe?containerRecipeArn=")

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

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

url = "{{baseUrl}}/DeleteContainerRecipe#containerRecipeArn"

querystring = {"containerRecipeArn":""}

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

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

url <- "{{baseUrl}}/DeleteContainerRecipe#containerRecipeArn"

queryString <- list(containerRecipeArn = "")

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

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

url = URI("{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn")

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/DeleteContainerRecipe') do |req|
  req.params['containerRecipeArn'] = ''
end

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

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

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

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

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

    dbg!(results);
}
curl --request DELETE \
  --url '{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn'
http DELETE '{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn'
wget --quiet \
  --method DELETE \
  --output-document \
  - '{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/DeleteContainerRecipe?containerRecipeArn=#containerRecipeArn")! 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 DeleteDistributionConfiguration
{{baseUrl}}/DeleteDistributionConfiguration#distributionConfigurationArn
QUERY PARAMS

distributionConfigurationArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn");

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

(client/delete "{{baseUrl}}/DeleteDistributionConfiguration#distributionConfigurationArn" {:query-params {:distributionConfigurationArn ""}})
require "http/client"

url = "{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn"

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

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

func main() {

	url := "{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn"

	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/DeleteDistributionConfiguration?distributionConfigurationArn= HTTP/1.1
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn")
  .asString();
const 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}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/DeleteDistributionConfiguration#distributionConfigurationArn',
  params: {distributionConfigurationArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn")
  .delete(null)
  .build()

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

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

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

  res.on('data', function (chunk) {
    chunks.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}}/DeleteDistributionConfiguration#distributionConfigurationArn',
  qs: {distributionConfigurationArn: ''}
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/DeleteDistributionConfiguration#distributionConfigurationArn');

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

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}}/DeleteDistributionConfiguration#distributionConfigurationArn',
  params: {distributionConfigurationArn: ''}
};

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

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

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

echo $response->getBody();
setUrl('{{baseUrl}}/DeleteDistributionConfiguration#distributionConfigurationArn');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/DeleteDistributionConfiguration?distributionConfigurationArn=")

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

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

url = "{{baseUrl}}/DeleteDistributionConfiguration#distributionConfigurationArn"

querystring = {"distributionConfigurationArn":""}

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

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

url <- "{{baseUrl}}/DeleteDistributionConfiguration#distributionConfigurationArn"

queryString <- list(distributionConfigurationArn = "")

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

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

url = URI("{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn")

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/DeleteDistributionConfiguration') do |req|
  req.params['distributionConfigurationArn'] = ''
end

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

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

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

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

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

    dbg!(results);
}
curl --request DELETE \
  --url '{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn'
http DELETE '{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn'
wget --quiet \
  --method DELETE \
  --output-document \
  - '{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/DeleteDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn")! 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 DeleteImage
{{baseUrl}}/DeleteImage#imageBuildVersionArn
QUERY PARAMS

imageBuildVersionArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn");

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

(client/delete "{{baseUrl}}/DeleteImage#imageBuildVersionArn" {:query-params {:imageBuildVersionArn ""}})
require "http/client"

url = "{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn"

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

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

func main() {

	url := "{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn"

	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/DeleteImage?imageBuildVersionArn= HTTP/1.1
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn")
  .asString();
const 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}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/DeleteImage#imageBuildVersionArn',
  params: {imageBuildVersionArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn")
  .delete(null)
  .build()

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

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

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

  res.on('data', function (chunk) {
    chunks.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}}/DeleteImage#imageBuildVersionArn',
  qs: {imageBuildVersionArn: ''}
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/DeleteImage#imageBuildVersionArn');

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

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}}/DeleteImage#imageBuildVersionArn',
  params: {imageBuildVersionArn: ''}
};

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

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

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

echo $response->getBody();
setUrl('{{baseUrl}}/DeleteImage#imageBuildVersionArn');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/DeleteImage?imageBuildVersionArn=")

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

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

url = "{{baseUrl}}/DeleteImage#imageBuildVersionArn"

querystring = {"imageBuildVersionArn":""}

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

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

url <- "{{baseUrl}}/DeleteImage#imageBuildVersionArn"

queryString <- list(imageBuildVersionArn = "")

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

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

url = URI("{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn")

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/DeleteImage') do |req|
  req.params['imageBuildVersionArn'] = ''
end

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

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

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

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

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

    dbg!(results);
}
curl --request DELETE \
  --url '{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn'
http DELETE '{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn'
wget --quiet \
  --method DELETE \
  --output-document \
  - '{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/DeleteImage?imageBuildVersionArn=#imageBuildVersionArn")! 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 DeleteImagePipeline
{{baseUrl}}/DeleteImagePipeline#imagePipelineArn
QUERY PARAMS

imagePipelineArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn");

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

(client/delete "{{baseUrl}}/DeleteImagePipeline#imagePipelineArn" {:query-params {:imagePipelineArn ""}})
require "http/client"

url = "{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn"

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

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

func main() {

	url := "{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn"

	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/DeleteImagePipeline?imagePipelineArn= HTTP/1.1
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn")
  .asString();
const 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}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/DeleteImagePipeline#imagePipelineArn',
  params: {imagePipelineArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn")
  .delete(null)
  .build()

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

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

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

  res.on('data', function (chunk) {
    chunks.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}}/DeleteImagePipeline#imagePipelineArn',
  qs: {imagePipelineArn: ''}
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/DeleteImagePipeline#imagePipelineArn');

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

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}}/DeleteImagePipeline#imagePipelineArn',
  params: {imagePipelineArn: ''}
};

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

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

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

echo $response->getBody();
setUrl('{{baseUrl}}/DeleteImagePipeline#imagePipelineArn');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/DeleteImagePipeline?imagePipelineArn=")

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

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

url = "{{baseUrl}}/DeleteImagePipeline#imagePipelineArn"

querystring = {"imagePipelineArn":""}

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

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

url <- "{{baseUrl}}/DeleteImagePipeline#imagePipelineArn"

queryString <- list(imagePipelineArn = "")

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

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

url = URI("{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn")

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/DeleteImagePipeline') do |req|
  req.params['imagePipelineArn'] = ''
end

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

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

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

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

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

    dbg!(results);
}
curl --request DELETE \
  --url '{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn'
http DELETE '{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn'
wget --quiet \
  --method DELETE \
  --output-document \
  - '{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/DeleteImagePipeline?imagePipelineArn=#imagePipelineArn")! 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 DeleteImageRecipe
{{baseUrl}}/DeleteImageRecipe#imageRecipeArn
QUERY PARAMS

imageRecipeArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn");

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

(client/delete "{{baseUrl}}/DeleteImageRecipe#imageRecipeArn" {:query-params {:imageRecipeArn ""}})
require "http/client"

url = "{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn"

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

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

func main() {

	url := "{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn"

	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/DeleteImageRecipe?imageRecipeArn= HTTP/1.1
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn")
  .asString();
const 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}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/DeleteImageRecipe#imageRecipeArn',
  params: {imageRecipeArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn")
  .delete(null)
  .build()

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

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

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

  res.on('data', function (chunk) {
    chunks.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}}/DeleteImageRecipe#imageRecipeArn',
  qs: {imageRecipeArn: ''}
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/DeleteImageRecipe#imageRecipeArn');

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

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}}/DeleteImageRecipe#imageRecipeArn',
  params: {imageRecipeArn: ''}
};

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

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

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

echo $response->getBody();
setUrl('{{baseUrl}}/DeleteImageRecipe#imageRecipeArn');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/DeleteImageRecipe?imageRecipeArn=")

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

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

url = "{{baseUrl}}/DeleteImageRecipe#imageRecipeArn"

querystring = {"imageRecipeArn":""}

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

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

url <- "{{baseUrl}}/DeleteImageRecipe#imageRecipeArn"

queryString <- list(imageRecipeArn = "")

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

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

url = URI("{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn")

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/DeleteImageRecipe') do |req|
  req.params['imageRecipeArn'] = ''
end

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

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

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

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

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

    dbg!(results);
}
curl --request DELETE \
  --url '{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn'
http DELETE '{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn'
wget --quiet \
  --method DELETE \
  --output-document \
  - '{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/DeleteImageRecipe?imageRecipeArn=#imageRecipeArn")! 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 DeleteInfrastructureConfiguration
{{baseUrl}}/DeleteInfrastructureConfiguration#infrastructureConfigurationArn
QUERY PARAMS

infrastructureConfigurationArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn");

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

(client/delete "{{baseUrl}}/DeleteInfrastructureConfiguration#infrastructureConfigurationArn" {:query-params {:infrastructureConfigurationArn ""}})
require "http/client"

url = "{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn"

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

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

func main() {

	url := "{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn"

	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/DeleteInfrastructureConfiguration?infrastructureConfigurationArn= HTTP/1.1
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn")
  .asString();
const 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}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/DeleteInfrastructureConfiguration#infrastructureConfigurationArn',
  params: {infrastructureConfigurationArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn")
  .delete(null)
  .build()

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

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

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

  res.on('data', function (chunk) {
    chunks.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}}/DeleteInfrastructureConfiguration#infrastructureConfigurationArn',
  qs: {infrastructureConfigurationArn: ''}
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/DeleteInfrastructureConfiguration#infrastructureConfigurationArn');

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

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}}/DeleteInfrastructureConfiguration#infrastructureConfigurationArn',
  params: {infrastructureConfigurationArn: ''}
};

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

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

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

echo $response->getBody();
setUrl('{{baseUrl}}/DeleteInfrastructureConfiguration#infrastructureConfigurationArn');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=")

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

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

url = "{{baseUrl}}/DeleteInfrastructureConfiguration#infrastructureConfigurationArn"

querystring = {"infrastructureConfigurationArn":""}

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

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

url <- "{{baseUrl}}/DeleteInfrastructureConfiguration#infrastructureConfigurationArn"

queryString <- list(infrastructureConfigurationArn = "")

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

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

url = URI("{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn")

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/DeleteInfrastructureConfiguration') do |req|
  req.params['infrastructureConfigurationArn'] = ''
end

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

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

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

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

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

    dbg!(results);
}
curl --request DELETE \
  --url '{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn'
http DELETE '{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn'
wget --quiet \
  --method DELETE \
  --output-document \
  - '{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/DeleteInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn")! 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 GetComponent
{{baseUrl}}/GetComponent#componentBuildVersionArn
QUERY PARAMS

componentBuildVersionArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn");

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

(client/get "{{baseUrl}}/GetComponent#componentBuildVersionArn" {:query-params {:componentBuildVersionArn ""}})
require "http/client"

url = "{{baseUrl}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn"

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

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

func main() {

	url := "{{baseUrl}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn"

	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/GetComponent?componentBuildVersionArn= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetComponent#componentBuildVersionArn',
  params: {componentBuildVersionArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetComponent?componentBuildVersionArn=',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetComponent#componentBuildVersionArn',
  qs: {componentBuildVersionArn: ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/GetComponent#componentBuildVersionArn');

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetComponent#componentBuildVersionArn',
  params: {componentBuildVersionArn: ''}
};

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

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

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/GetComponent?componentBuildVersionArn=")

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

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

url = "{{baseUrl}}/GetComponent#componentBuildVersionArn"

querystring = {"componentBuildVersionArn":""}

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

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

url <- "{{baseUrl}}/GetComponent#componentBuildVersionArn"

queryString <- list(componentBuildVersionArn = "")

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

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

url = URI("{{baseUrl}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn")

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/GetComponent') do |req|
  req.params['componentBuildVersionArn'] = ''
end

puts response.status
puts response.body
use reqwest;

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

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

    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}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn'
http GET '{{baseUrl}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetComponent?componentBuildVersionArn=#componentBuildVersionArn")! 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 GetComponentPolicy
{{baseUrl}}/GetComponentPolicy#componentArn
QUERY PARAMS

componentArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetComponentPolicy?componentArn=#componentArn");

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

(client/get "{{baseUrl}}/GetComponentPolicy#componentArn" {:query-params {:componentArn ""}})
require "http/client"

url = "{{baseUrl}}/GetComponentPolicy?componentArn=#componentArn"

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

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

func main() {

	url := "{{baseUrl}}/GetComponentPolicy?componentArn=#componentArn"

	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/GetComponentPolicy?componentArn= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetComponentPolicy?componentArn=#componentArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetComponentPolicy?componentArn=#componentArn")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/GetComponentPolicy?componentArn=#componentArn');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetComponentPolicy#componentArn',
  params: {componentArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/GetComponentPolicy?componentArn=#componentArn")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetComponentPolicy?componentArn=',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetComponentPolicy#componentArn',
  qs: {componentArn: ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/GetComponentPolicy#componentArn');

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetComponentPolicy#componentArn',
  params: {componentArn: ''}
};

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

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

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/GetComponentPolicy?componentArn=")

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

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

url = "{{baseUrl}}/GetComponentPolicy#componentArn"

querystring = {"componentArn":""}

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

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

url <- "{{baseUrl}}/GetComponentPolicy#componentArn"

queryString <- list(componentArn = "")

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

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

url = URI("{{baseUrl}}/GetComponentPolicy?componentArn=#componentArn")

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/GetComponentPolicy') do |req|
  req.params['componentArn'] = ''
end

puts response.status
puts response.body
use reqwest;

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

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

    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}}/GetComponentPolicy?componentArn=#componentArn'
http GET '{{baseUrl}}/GetComponentPolicy?componentArn=#componentArn'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetComponentPolicy?componentArn=#componentArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetComponentPolicy?componentArn=#componentArn")! 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 GetContainerRecipe
{{baseUrl}}/GetContainerRecipe#containerRecipeArn
QUERY PARAMS

containerRecipeArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn");

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

(client/get "{{baseUrl}}/GetContainerRecipe#containerRecipeArn" {:query-params {:containerRecipeArn ""}})
require "http/client"

url = "{{baseUrl}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn"

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

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

func main() {

	url := "{{baseUrl}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn"

	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/GetContainerRecipe?containerRecipeArn= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetContainerRecipe#containerRecipeArn',
  params: {containerRecipeArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetContainerRecipe?containerRecipeArn=',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetContainerRecipe#containerRecipeArn',
  qs: {containerRecipeArn: ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/GetContainerRecipe#containerRecipeArn');

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetContainerRecipe#containerRecipeArn',
  params: {containerRecipeArn: ''}
};

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

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

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/GetContainerRecipe?containerRecipeArn=")

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

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

url = "{{baseUrl}}/GetContainerRecipe#containerRecipeArn"

querystring = {"containerRecipeArn":""}

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

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

url <- "{{baseUrl}}/GetContainerRecipe#containerRecipeArn"

queryString <- list(containerRecipeArn = "")

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

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

url = URI("{{baseUrl}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn")

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/GetContainerRecipe') do |req|
  req.params['containerRecipeArn'] = ''
end

puts response.status
puts response.body
use reqwest;

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

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

    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}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn'
http GET '{{baseUrl}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetContainerRecipe?containerRecipeArn=#containerRecipeArn")! 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 GetContainerRecipePolicy
{{baseUrl}}/GetContainerRecipePolicy#containerRecipeArn
QUERY PARAMS

containerRecipeArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn");

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

(client/get "{{baseUrl}}/GetContainerRecipePolicy#containerRecipeArn" {:query-params {:containerRecipeArn ""}})
require "http/client"

url = "{{baseUrl}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn"

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

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

func main() {

	url := "{{baseUrl}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn"

	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/GetContainerRecipePolicy?containerRecipeArn= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetContainerRecipePolicy#containerRecipeArn',
  params: {containerRecipeArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetContainerRecipePolicy?containerRecipeArn=',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetContainerRecipePolicy#containerRecipeArn',
  qs: {containerRecipeArn: ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/GetContainerRecipePolicy#containerRecipeArn');

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetContainerRecipePolicy#containerRecipeArn',
  params: {containerRecipeArn: ''}
};

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

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

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/GetContainerRecipePolicy?containerRecipeArn=")

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

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

url = "{{baseUrl}}/GetContainerRecipePolicy#containerRecipeArn"

querystring = {"containerRecipeArn":""}

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

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

url <- "{{baseUrl}}/GetContainerRecipePolicy#containerRecipeArn"

queryString <- list(containerRecipeArn = "")

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

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

url = URI("{{baseUrl}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn")

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/GetContainerRecipePolicy') do |req|
  req.params['containerRecipeArn'] = ''
end

puts response.status
puts response.body
use reqwest;

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

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

    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}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn'
http GET '{{baseUrl}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetContainerRecipePolicy?containerRecipeArn=#containerRecipeArn")! 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 GetDistributionConfiguration
{{baseUrl}}/GetDistributionConfiguration#distributionConfigurationArn
QUERY PARAMS

distributionConfigurationArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn");

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

(client/get "{{baseUrl}}/GetDistributionConfiguration#distributionConfigurationArn" {:query-params {:distributionConfigurationArn ""}})
require "http/client"

url = "{{baseUrl}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn"

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

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

func main() {

	url := "{{baseUrl}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn"

	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/GetDistributionConfiguration?distributionConfigurationArn= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetDistributionConfiguration#distributionConfigurationArn',
  params: {distributionConfigurationArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetDistributionConfiguration?distributionConfigurationArn=',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetDistributionConfiguration#distributionConfigurationArn',
  qs: {distributionConfigurationArn: ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/GetDistributionConfiguration#distributionConfigurationArn');

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetDistributionConfiguration#distributionConfigurationArn',
  params: {distributionConfigurationArn: ''}
};

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

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

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/GetDistributionConfiguration?distributionConfigurationArn=")

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

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

url = "{{baseUrl}}/GetDistributionConfiguration#distributionConfigurationArn"

querystring = {"distributionConfigurationArn":""}

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

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

url <- "{{baseUrl}}/GetDistributionConfiguration#distributionConfigurationArn"

queryString <- list(distributionConfigurationArn = "")

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

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

url = URI("{{baseUrl}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn")

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/GetDistributionConfiguration') do |req|
  req.params['distributionConfigurationArn'] = ''
end

puts response.status
puts response.body
use reqwest;

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

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

    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}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn'
http GET '{{baseUrl}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetDistributionConfiguration?distributionConfigurationArn=#distributionConfigurationArn")! 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 GetImage
{{baseUrl}}/GetImage#imageBuildVersionArn
QUERY PARAMS

imageBuildVersionArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn");

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

(client/get "{{baseUrl}}/GetImage#imageBuildVersionArn" {:query-params {:imageBuildVersionArn ""}})
require "http/client"

url = "{{baseUrl}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn"

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

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

func main() {

	url := "{{baseUrl}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn"

	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/GetImage?imageBuildVersionArn= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImage#imageBuildVersionArn',
  params: {imageBuildVersionArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetImage?imageBuildVersionArn=',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImage#imageBuildVersionArn',
  qs: {imageBuildVersionArn: ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/GetImage#imageBuildVersionArn');

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImage#imageBuildVersionArn',
  params: {imageBuildVersionArn: ''}
};

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

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

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/GetImage?imageBuildVersionArn=")

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

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

url = "{{baseUrl}}/GetImage#imageBuildVersionArn"

querystring = {"imageBuildVersionArn":""}

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

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

url <- "{{baseUrl}}/GetImage#imageBuildVersionArn"

queryString <- list(imageBuildVersionArn = "")

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

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

url = URI("{{baseUrl}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn")

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/GetImage') do |req|
  req.params['imageBuildVersionArn'] = ''
end

puts response.status
puts response.body
use reqwest;

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

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

    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}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn'
http GET '{{baseUrl}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetImage?imageBuildVersionArn=#imageBuildVersionArn")! 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 GetImagePipeline
{{baseUrl}}/GetImagePipeline#imagePipelineArn
QUERY PARAMS

imagePipelineArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn");

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

(client/get "{{baseUrl}}/GetImagePipeline#imagePipelineArn" {:query-params {:imagePipelineArn ""}})
require "http/client"

url = "{{baseUrl}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn"

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

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

func main() {

	url := "{{baseUrl}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn"

	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/GetImagePipeline?imagePipelineArn= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImagePipeline#imagePipelineArn',
  params: {imagePipelineArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetImagePipeline?imagePipelineArn=',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImagePipeline#imagePipelineArn',
  qs: {imagePipelineArn: ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/GetImagePipeline#imagePipelineArn');

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImagePipeline#imagePipelineArn',
  params: {imagePipelineArn: ''}
};

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

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

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/GetImagePipeline?imagePipelineArn=")

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

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

url = "{{baseUrl}}/GetImagePipeline#imagePipelineArn"

querystring = {"imagePipelineArn":""}

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

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

url <- "{{baseUrl}}/GetImagePipeline#imagePipelineArn"

queryString <- list(imagePipelineArn = "")

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

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

url = URI("{{baseUrl}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn")

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/GetImagePipeline') do |req|
  req.params['imagePipelineArn'] = ''
end

puts response.status
puts response.body
use reqwest;

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

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

    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}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn'
http GET '{{baseUrl}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetImagePipeline?imagePipelineArn=#imagePipelineArn")! 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 GetImagePolicy
{{baseUrl}}/GetImagePolicy#imageArn
QUERY PARAMS

imageArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetImagePolicy?imageArn=#imageArn");

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

(client/get "{{baseUrl}}/GetImagePolicy#imageArn" {:query-params {:imageArn ""}})
require "http/client"

url = "{{baseUrl}}/GetImagePolicy?imageArn=#imageArn"

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

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

func main() {

	url := "{{baseUrl}}/GetImagePolicy?imageArn=#imageArn"

	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/GetImagePolicy?imageArn= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetImagePolicy?imageArn=#imageArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetImagePolicy?imageArn=#imageArn")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/GetImagePolicy?imageArn=#imageArn');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImagePolicy#imageArn',
  params: {imageArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/GetImagePolicy?imageArn=#imageArn")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetImagePolicy?imageArn=',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImagePolicy#imageArn',
  qs: {imageArn: ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/GetImagePolicy#imageArn');

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImagePolicy#imageArn',
  params: {imageArn: ''}
};

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

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

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/GetImagePolicy?imageArn=")

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

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

url = "{{baseUrl}}/GetImagePolicy#imageArn"

querystring = {"imageArn":""}

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

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

url <- "{{baseUrl}}/GetImagePolicy#imageArn"

queryString <- list(imageArn = "")

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

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

url = URI("{{baseUrl}}/GetImagePolicy?imageArn=#imageArn")

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/GetImagePolicy') do |req|
  req.params['imageArn'] = ''
end

puts response.status
puts response.body
use reqwest;

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

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

    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}}/GetImagePolicy?imageArn=#imageArn'
http GET '{{baseUrl}}/GetImagePolicy?imageArn=#imageArn'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetImagePolicy?imageArn=#imageArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetImagePolicy?imageArn=#imageArn")! 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 GetImageRecipe
{{baseUrl}}/GetImageRecipe#imageRecipeArn
QUERY PARAMS

imageRecipeArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn");

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

(client/get "{{baseUrl}}/GetImageRecipe#imageRecipeArn" {:query-params {:imageRecipeArn ""}})
require "http/client"

url = "{{baseUrl}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn"

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

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

func main() {

	url := "{{baseUrl}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn"

	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/GetImageRecipe?imageRecipeArn= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImageRecipe#imageRecipeArn',
  params: {imageRecipeArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetImageRecipe?imageRecipeArn=',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImageRecipe#imageRecipeArn',
  qs: {imageRecipeArn: ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/GetImageRecipe#imageRecipeArn');

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImageRecipe#imageRecipeArn',
  params: {imageRecipeArn: ''}
};

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

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

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/GetImageRecipe?imageRecipeArn=")

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

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

url = "{{baseUrl}}/GetImageRecipe#imageRecipeArn"

querystring = {"imageRecipeArn":""}

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

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

url <- "{{baseUrl}}/GetImageRecipe#imageRecipeArn"

queryString <- list(imageRecipeArn = "")

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

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

url = URI("{{baseUrl}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn")

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/GetImageRecipe') do |req|
  req.params['imageRecipeArn'] = ''
end

puts response.status
puts response.body
use reqwest;

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

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

    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}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn'
http GET '{{baseUrl}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetImageRecipe?imageRecipeArn=#imageRecipeArn")! 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 GetImageRecipePolicy
{{baseUrl}}/GetImageRecipePolicy#imageRecipeArn
QUERY PARAMS

imageRecipeArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn");

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

(client/get "{{baseUrl}}/GetImageRecipePolicy#imageRecipeArn" {:query-params {:imageRecipeArn ""}})
require "http/client"

url = "{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn"

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

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

func main() {

	url := "{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn"

	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/GetImageRecipePolicy?imageRecipeArn= HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImageRecipePolicy#imageRecipeArn',
  params: {imageRecipeArn: ''}
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetImageRecipePolicy?imageRecipeArn=',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImageRecipePolicy#imageRecipeArn',
  qs: {imageRecipeArn: ''}
};

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

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

const req = unirest('GET', '{{baseUrl}}/GetImageRecipePolicy#imageRecipeArn');

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetImageRecipePolicy#imageRecipeArn',
  params: {imageRecipeArn: ''}
};

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

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

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn",
  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}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn');

echo $response->getBody();
setUrl('{{baseUrl}}/GetImageRecipePolicy#imageRecipeArn');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'imageRecipeArn' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/GetImageRecipePolicy#imageRecipeArn');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'imageRecipeArn' => ''
]));

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/GetImageRecipePolicy?imageRecipeArn=")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/GetImageRecipePolicy#imageRecipeArn"

querystring = {"imageRecipeArn":""}

response = requests.get(url, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/GetImageRecipePolicy#imageRecipeArn"

queryString <- list(imageRecipeArn = "")

response <- VERB("GET", url, query = queryString, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn")

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/GetImageRecipePolicy') do |req|
  req.params['imageRecipeArn'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/GetImageRecipePolicy#imageRecipeArn";

    let querystring = [
        ("imageRecipeArn", ""),
    ];

    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}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn'
http GET '{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetImageRecipePolicy?imageRecipeArn=#imageRecipeArn")! 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 GetInfrastructureConfiguration
{{baseUrl}}/GetInfrastructureConfiguration#infrastructureConfigurationArn
QUERY PARAMS

infrastructureConfigurationArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/GetInfrastructureConfiguration#infrastructureConfigurationArn" {:query-params {:infrastructureConfigurationArn ""}})
require "http/client"

url = "{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn"

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}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn"

	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/GetInfrastructureConfiguration?infrastructureConfigurationArn= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetInfrastructureConfiguration#infrastructureConfigurationArn',
  params: {infrastructureConfigurationArn: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn';
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}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetInfrastructureConfiguration?infrastructureConfigurationArn=',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetInfrastructureConfiguration#infrastructureConfigurationArn',
  qs: {infrastructureConfigurationArn: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/GetInfrastructureConfiguration#infrastructureConfigurationArn');

req.query({
  infrastructureConfigurationArn: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetInfrastructureConfiguration#infrastructureConfigurationArn',
  params: {infrastructureConfigurationArn: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn';
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}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn"]
                                                       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}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn",
  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}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn');

echo $response->getBody();
setUrl('{{baseUrl}}/GetInfrastructureConfiguration#infrastructureConfigurationArn');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'infrastructureConfigurationArn' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/GetInfrastructureConfiguration#infrastructureConfigurationArn');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'infrastructureConfigurationArn' => ''
]));

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/GetInfrastructureConfiguration?infrastructureConfigurationArn=")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/GetInfrastructureConfiguration#infrastructureConfigurationArn"

querystring = {"infrastructureConfigurationArn":""}

response = requests.get(url, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/GetInfrastructureConfiguration#infrastructureConfigurationArn"

queryString <- list(infrastructureConfigurationArn = "")

response <- VERB("GET", url, query = queryString, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn")

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/GetInfrastructureConfiguration') do |req|
  req.params['infrastructureConfigurationArn'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/GetInfrastructureConfiguration#infrastructureConfigurationArn";

    let querystring = [
        ("infrastructureConfigurationArn", ""),
    ];

    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}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn'
http GET '{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetInfrastructureConfiguration?infrastructureConfigurationArn=#infrastructureConfigurationArn")! 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 GetWorkflowExecution
{{baseUrl}}/GetWorkflowExecution#workflowExecutionId
QUERY PARAMS

workflowExecutionId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/GetWorkflowExecution#workflowExecutionId" {:query-params {:workflowExecutionId ""}})
require "http/client"

url = "{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId"

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}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId"

	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/GetWorkflowExecution?workflowExecutionId= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetWorkflowExecution#workflowExecutionId',
  params: {workflowExecutionId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId';
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}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetWorkflowExecution?workflowExecutionId=',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetWorkflowExecution#workflowExecutionId',
  qs: {workflowExecutionId: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/GetWorkflowExecution#workflowExecutionId');

req.query({
  workflowExecutionId: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetWorkflowExecution#workflowExecutionId',
  params: {workflowExecutionId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId';
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}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId"]
                                                       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}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId",
  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}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId');

echo $response->getBody();
setUrl('{{baseUrl}}/GetWorkflowExecution#workflowExecutionId');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'workflowExecutionId' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/GetWorkflowExecution#workflowExecutionId');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'workflowExecutionId' => ''
]));

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/GetWorkflowExecution?workflowExecutionId=")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/GetWorkflowExecution#workflowExecutionId"

querystring = {"workflowExecutionId":""}

response = requests.get(url, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/GetWorkflowExecution#workflowExecutionId"

queryString <- list(workflowExecutionId = "")

response <- VERB("GET", url, query = queryString, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId")

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/GetWorkflowExecution') do |req|
  req.params['workflowExecutionId'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/GetWorkflowExecution#workflowExecutionId";

    let querystring = [
        ("workflowExecutionId", ""),
    ];

    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}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId'
http GET '{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetWorkflowExecution?workflowExecutionId=#workflowExecutionId")! 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 GetWorkflowStepExecution
{{baseUrl}}/GetWorkflowStepExecution#stepExecutionId
QUERY PARAMS

stepExecutionId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/GetWorkflowStepExecution#stepExecutionId" {:query-params {:stepExecutionId ""}})
require "http/client"

url = "{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId"

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}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId"

	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/GetWorkflowStepExecution?stepExecutionId= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetWorkflowStepExecution#stepExecutionId',
  params: {stepExecutionId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId';
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}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/GetWorkflowStepExecution?stepExecutionId=',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetWorkflowStepExecution#stepExecutionId',
  qs: {stepExecutionId: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/GetWorkflowStepExecution#stepExecutionId');

req.query({
  stepExecutionId: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/GetWorkflowStepExecution#stepExecutionId',
  params: {stepExecutionId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId';
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}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId"]
                                                       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}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId",
  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}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId');

echo $response->getBody();
setUrl('{{baseUrl}}/GetWorkflowStepExecution#stepExecutionId');
$request->setMethod(HTTP_METH_GET);

$request->setQueryData([
  'stepExecutionId' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/GetWorkflowStepExecution#stepExecutionId');
$request->setRequestMethod('GET');
$request->setQuery(new http\QueryString([
  'stepExecutionId' => ''
]));

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/GetWorkflowStepExecution?stepExecutionId=")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/GetWorkflowStepExecution#stepExecutionId"

querystring = {"stepExecutionId":""}

response = requests.get(url, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/GetWorkflowStepExecution#stepExecutionId"

queryString <- list(stepExecutionId = "")

response <- VERB("GET", url, query = queryString, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId")

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/GetWorkflowStepExecution') do |req|
  req.params['stepExecutionId'] = ''
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/GetWorkflowStepExecution#stepExecutionId";

    let querystring = [
        ("stepExecutionId", ""),
    ];

    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}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId'
http GET '{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId'
wget --quiet \
  --method GET \
  --output-document \
  - '{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/GetWorkflowStepExecution?stepExecutionId=#stepExecutionId")! 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 ImportComponent
{{baseUrl}}/ImportComponent
BODY json

{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "type": "",
  "format": "",
  "platform": "",
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ImportComponent");

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  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/ImportComponent" {:content-type :json
                                                           :form-params {:name ""
                                                                         :semanticVersion ""
                                                                         :description ""
                                                                         :changeDescription ""
                                                                         :type ""
                                                                         :format ""
                                                                         :platform ""
                                                                         :data ""
                                                                         :uri ""
                                                                         :kmsKeyId ""
                                                                         :tags {}
                                                                         :clientToken ""}})
require "http/client"

url = "{{baseUrl}}/ImportComponent"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/ImportComponent"),
    Content = new StringContent("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ImportComponent");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ImportComponent"

	payload := strings.NewReader("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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/ImportComponent HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 217

{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "type": "",
  "format": "",
  "platform": "",
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/ImportComponent")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ImportComponent"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ImportComponent")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/ImportComponent")
  .header("content-type", "application/json")
  .body("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  name: '',
  semanticVersion: '',
  description: '',
  changeDescription: '',
  type: '',
  format: '',
  platform: '',
  data: '',
  uri: '',
  kmsKeyId: '',
  tags: {},
  clientToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/ImportComponent');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/ImportComponent',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    semanticVersion: '',
    description: '',
    changeDescription: '',
    type: '',
    format: '',
    platform: '',
    data: '',
    uri: '',
    kmsKeyId: '',
    tags: {},
    clientToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ImportComponent';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","semanticVersion":"","description":"","changeDescription":"","type":"","format":"","platform":"","data":"","uri":"","kmsKeyId":"","tags":{},"clientToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ImportComponent',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name": "",\n  "semanticVersion": "",\n  "description": "",\n  "changeDescription": "",\n  "type": "",\n  "format": "",\n  "platform": "",\n  "data": "",\n  "uri": "",\n  "kmsKeyId": "",\n  "tags": {},\n  "clientToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ImportComponent")
  .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/ImportComponent',
  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({
  name: '',
  semanticVersion: '',
  description: '',
  changeDescription: '',
  type: '',
  format: '',
  platform: '',
  data: '',
  uri: '',
  kmsKeyId: '',
  tags: {},
  clientToken: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/ImportComponent',
  headers: {'content-type': 'application/json'},
  body: {
    name: '',
    semanticVersion: '',
    description: '',
    changeDescription: '',
    type: '',
    format: '',
    platform: '',
    data: '',
    uri: '',
    kmsKeyId: '',
    tags: {},
    clientToken: ''
  },
  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}}/ImportComponent');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  name: '',
  semanticVersion: '',
  description: '',
  changeDescription: '',
  type: '',
  format: '',
  platform: '',
  data: '',
  uri: '',
  kmsKeyId: '',
  tags: {},
  clientToken: ''
});

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}}/ImportComponent',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    semanticVersion: '',
    description: '',
    changeDescription: '',
    type: '',
    format: '',
    platform: '',
    data: '',
    uri: '',
    kmsKeyId: '',
    tags: {},
    clientToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ImportComponent';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","semanticVersion":"","description":"","changeDescription":"","type":"","format":"","platform":"","data":"","uri":"","kmsKeyId":"","tags":{},"clientToken":""}'
};

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 = @{ @"name": @"",
                              @"semanticVersion": @"",
                              @"description": @"",
                              @"changeDescription": @"",
                              @"type": @"",
                              @"format": @"",
                              @"platform": @"",
                              @"data": @"",
                              @"uri": @"",
                              @"kmsKeyId": @"",
                              @"tags": @{  },
                              @"clientToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ImportComponent"]
                                                       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}}/ImportComponent" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ImportComponent",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'name' => '',
    'semanticVersion' => '',
    'description' => '',
    'changeDescription' => '',
    'type' => '',
    'format' => '',
    'platform' => '',
    'data' => '',
    'uri' => '',
    'kmsKeyId' => '',
    'tags' => [
        
    ],
    'clientToken' => ''
  ]),
  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}}/ImportComponent', [
  'body' => '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "type": "",
  "format": "",
  "platform": "",
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ImportComponent');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name' => '',
  'semanticVersion' => '',
  'description' => '',
  'changeDescription' => '',
  'type' => '',
  'format' => '',
  'platform' => '',
  'data' => '',
  'uri' => '',
  'kmsKeyId' => '',
  'tags' => [
    
  ],
  'clientToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name' => '',
  'semanticVersion' => '',
  'description' => '',
  'changeDescription' => '',
  'type' => '',
  'format' => '',
  'platform' => '',
  'data' => '',
  'uri' => '',
  'kmsKeyId' => '',
  'tags' => [
    
  ],
  'clientToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ImportComponent');
$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}}/ImportComponent' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "type": "",
  "format": "",
  "platform": "",
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ImportComponent' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "type": "",
  "format": "",
  "platform": "",
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/ImportComponent", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ImportComponent"

payload = {
    "name": "",
    "semanticVersion": "",
    "description": "",
    "changeDescription": "",
    "type": "",
    "format": "",
    "platform": "",
    "data": "",
    "uri": "",
    "kmsKeyId": "",
    "tags": {},
    "clientToken": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ImportComponent"

payload <- "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/ImportComponent")

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  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"

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/ImportComponent') do |req|
  req.body = "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"changeDescription\": \"\",\n  \"type\": \"\",\n  \"format\": \"\",\n  \"platform\": \"\",\n  \"data\": \"\",\n  \"uri\": \"\",\n  \"kmsKeyId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/ImportComponent";

    let payload = json!({
        "name": "",
        "semanticVersion": "",
        "description": "",
        "changeDescription": "",
        "type": "",
        "format": "",
        "platform": "",
        "data": "",
        "uri": "",
        "kmsKeyId": "",
        "tags": json!({}),
        "clientToken": ""
    });

    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}}/ImportComponent \
  --header 'content-type: application/json' \
  --data '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "type": "",
  "format": "",
  "platform": "",
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}'
echo '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "type": "",
  "format": "",
  "platform": "",
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": {},
  "clientToken": ""
}' |  \
  http PUT {{baseUrl}}/ImportComponent \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": "",\n  "semanticVersion": "",\n  "description": "",\n  "changeDescription": "",\n  "type": "",\n  "format": "",\n  "platform": "",\n  "data": "",\n  "uri": "",\n  "kmsKeyId": "",\n  "tags": {},\n  "clientToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ImportComponent
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "name": "",
  "semanticVersion": "",
  "description": "",
  "changeDescription": "",
  "type": "",
  "format": "",
  "platform": "",
  "data": "",
  "uri": "",
  "kmsKeyId": "",
  "tags": [],
  "clientToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ImportComponent")! 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 ImportVmImage
{{baseUrl}}/ImportVmImage
BODY json

{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "platform": "",
  "osVersion": "",
  "vmImportTaskId": "",
  "tags": {},
  "clientToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ImportVmImage");

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  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/ImportVmImage" {:content-type :json
                                                         :form-params {:name ""
                                                                       :semanticVersion ""
                                                                       :description ""
                                                                       :platform ""
                                                                       :osVersion ""
                                                                       :vmImportTaskId ""
                                                                       :tags {}
                                                                       :clientToken ""}})
require "http/client"

url = "{{baseUrl}}/ImportVmImage"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/ImportVmImage"),
    Content = new StringContent("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ImportVmImage");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ImportVmImage"

	payload := strings.NewReader("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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/ImportVmImage HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 158

{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "platform": "",
  "osVersion": "",
  "vmImportTaskId": "",
  "tags": {},
  "clientToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/ImportVmImage")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ImportVmImage"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ImportVmImage")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/ImportVmImage")
  .header("content-type", "application/json")
  .body("{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  name: '',
  semanticVersion: '',
  description: '',
  platform: '',
  osVersion: '',
  vmImportTaskId: '',
  tags: {},
  clientToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/ImportVmImage');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/ImportVmImage',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    semanticVersion: '',
    description: '',
    platform: '',
    osVersion: '',
    vmImportTaskId: '',
    tags: {},
    clientToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ImportVmImage';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","semanticVersion":"","description":"","platform":"","osVersion":"","vmImportTaskId":"","tags":{},"clientToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ImportVmImage',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name": "",\n  "semanticVersion": "",\n  "description": "",\n  "platform": "",\n  "osVersion": "",\n  "vmImportTaskId": "",\n  "tags": {},\n  "clientToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ImportVmImage")
  .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/ImportVmImage',
  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({
  name: '',
  semanticVersion: '',
  description: '',
  platform: '',
  osVersion: '',
  vmImportTaskId: '',
  tags: {},
  clientToken: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/ImportVmImage',
  headers: {'content-type': 'application/json'},
  body: {
    name: '',
    semanticVersion: '',
    description: '',
    platform: '',
    osVersion: '',
    vmImportTaskId: '',
    tags: {},
    clientToken: ''
  },
  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}}/ImportVmImage');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  name: '',
  semanticVersion: '',
  description: '',
  platform: '',
  osVersion: '',
  vmImportTaskId: '',
  tags: {},
  clientToken: ''
});

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}}/ImportVmImage',
  headers: {'content-type': 'application/json'},
  data: {
    name: '',
    semanticVersion: '',
    description: '',
    platform: '',
    osVersion: '',
    vmImportTaskId: '',
    tags: {},
    clientToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ImportVmImage';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","semanticVersion":"","description":"","platform":"","osVersion":"","vmImportTaskId":"","tags":{},"clientToken":""}'
};

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 = @{ @"name": @"",
                              @"semanticVersion": @"",
                              @"description": @"",
                              @"platform": @"",
                              @"osVersion": @"",
                              @"vmImportTaskId": @"",
                              @"tags": @{  },
                              @"clientToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ImportVmImage"]
                                                       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}}/ImportVmImage" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ImportVmImage",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'name' => '',
    'semanticVersion' => '',
    'description' => '',
    'platform' => '',
    'osVersion' => '',
    'vmImportTaskId' => '',
    'tags' => [
        
    ],
    'clientToken' => ''
  ]),
  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}}/ImportVmImage', [
  'body' => '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "platform": "",
  "osVersion": "",
  "vmImportTaskId": "",
  "tags": {},
  "clientToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ImportVmImage');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name' => '',
  'semanticVersion' => '',
  'description' => '',
  'platform' => '',
  'osVersion' => '',
  'vmImportTaskId' => '',
  'tags' => [
    
  ],
  'clientToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name' => '',
  'semanticVersion' => '',
  'description' => '',
  'platform' => '',
  'osVersion' => '',
  'vmImportTaskId' => '',
  'tags' => [
    
  ],
  'clientToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ImportVmImage');
$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}}/ImportVmImage' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "platform": "",
  "osVersion": "",
  "vmImportTaskId": "",
  "tags": {},
  "clientToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ImportVmImage' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "platform": "",
  "osVersion": "",
  "vmImportTaskId": "",
  "tags": {},
  "clientToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/ImportVmImage", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ImportVmImage"

payload = {
    "name": "",
    "semanticVersion": "",
    "description": "",
    "platform": "",
    "osVersion": "",
    "vmImportTaskId": "",
    "tags": {},
    "clientToken": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ImportVmImage"

payload <- "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/ImportVmImage")

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  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\n}"

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/ImportVmImage') do |req|
  req.body = "{\n  \"name\": \"\",\n  \"semanticVersion\": \"\",\n  \"description\": \"\",\n  \"platform\": \"\",\n  \"osVersion\": \"\",\n  \"vmImportTaskId\": \"\",\n  \"tags\": {},\n  \"clientToken\": \"\"\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}}/ImportVmImage";

    let payload = json!({
        "name": "",
        "semanticVersion": "",
        "description": "",
        "platform": "",
        "osVersion": "",
        "vmImportTaskId": "",
        "tags": json!({}),
        "clientToken": ""
    });

    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}}/ImportVmImage \
  --header 'content-type: application/json' \
  --data '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "platform": "",
  "osVersion": "",
  "vmImportTaskId": "",
  "tags": {},
  "clientToken": ""
}'
echo '{
  "name": "",
  "semanticVersion": "",
  "description": "",
  "platform": "",
  "osVersion": "",
  "vmImportTaskId": "",
  "tags": {},
  "clientToken": ""
}' |  \
  http PUT {{baseUrl}}/ImportVmImage \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": "",\n  "semanticVersion": "",\n  "description": "",\n  "platform": "",\n  "osVersion": "",\n  "vmImportTaskId": "",\n  "tags": {},\n  "clientToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ImportVmImage
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "name": "",
  "semanticVersion": "",
  "description": "",
  "platform": "",
  "osVersion": "",
  "vmImportTaskId": "",
  "tags": [],
  "clientToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ImportVmImage")! 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 ListComponentBuildVersions
{{baseUrl}}/ListComponentBuildVersions
BODY json

{
  "componentVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListComponentBuildVersions");

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  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListComponentBuildVersions" {:content-type :json
                                                                       :form-params {:componentVersionArn ""
                                                                                     :maxResults 0
                                                                                     :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListComponentBuildVersions"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListComponentBuildVersions"),
    Content = new StringContent("{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListComponentBuildVersions");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListComponentBuildVersions"

	payload := strings.NewReader("{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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/ListComponentBuildVersions HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 69

{
  "componentVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListComponentBuildVersions")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListComponentBuildVersions"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListComponentBuildVersions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListComponentBuildVersions")
  .header("content-type", "application/json")
  .body("{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  componentVersionArn: '',
  maxResults: 0,
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListComponentBuildVersions');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListComponentBuildVersions',
  headers: {'content-type': 'application/json'},
  data: {componentVersionArn: '', maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListComponentBuildVersions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"componentVersionArn":"","maxResults":0,"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListComponentBuildVersions',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "componentVersionArn": "",\n  "maxResults": 0,\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListComponentBuildVersions")
  .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/ListComponentBuildVersions',
  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({componentVersionArn: '', maxResults: 0, nextToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListComponentBuildVersions',
  headers: {'content-type': 'application/json'},
  body: {componentVersionArn: '', maxResults: 0, nextToken: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListComponentBuildVersions');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  componentVersionArn: '',
  maxResults: 0,
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListComponentBuildVersions',
  headers: {'content-type': 'application/json'},
  data: {componentVersionArn: '', maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListComponentBuildVersions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"componentVersionArn":"","maxResults":0,"nextToken":""}'
};

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 = @{ @"componentVersionArn": @"",
                              @"maxResults": @0,
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListComponentBuildVersions"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListComponentBuildVersions" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListComponentBuildVersions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'componentVersionArn' => '',
    'maxResults' => 0,
    'nextToken' => ''
  ]),
  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}}/ListComponentBuildVersions', [
  'body' => '{
  "componentVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListComponentBuildVersions');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'componentVersionArn' => '',
  'maxResults' => 0,
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'componentVersionArn' => '',
  'maxResults' => 0,
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListComponentBuildVersions');
$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}}/ListComponentBuildVersions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "componentVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListComponentBuildVersions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "componentVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListComponentBuildVersions", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListComponentBuildVersions"

payload = {
    "componentVersionArn": "",
    "maxResults": 0,
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListComponentBuildVersions"

payload <- "{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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}}/ListComponentBuildVersions")

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  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListComponentBuildVersions') do |req|
  req.body = "{\n  \"componentVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListComponentBuildVersions";

    let payload = json!({
        "componentVersionArn": "",
        "maxResults": 0,
        "nextToken": ""
    });

    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}}/ListComponentBuildVersions \
  --header 'content-type: application/json' \
  --data '{
  "componentVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}'
echo '{
  "componentVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListComponentBuildVersions \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "componentVersionArn": "",\n  "maxResults": 0,\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListComponentBuildVersions
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "componentVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListComponentBuildVersions")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListComponents
{{baseUrl}}/ListComponents
BODY json

{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListComponents");

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  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListComponents" {:content-type :json
                                                           :form-params {:owner ""
                                                                         :filters [{:name ""
                                                                                    :values ""}]
                                                                         :byName false
                                                                         :maxResults 0
                                                                         :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListComponents"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListComponents"),
    Content = new StringContent("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListComponents");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListComponents"

	payload := strings.NewReader("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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/ListComponents HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 143

{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListComponents")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListComponents"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListComponents")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListComponents")
  .header("content-type", "application/json")
  .body("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  owner: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  byName: false,
  maxResults: 0,
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListComponents');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListComponents',
  headers: {'content-type': 'application/json'},
  data: {
    owner: '',
    filters: [{name: '', values: ''}],
    byName: false,
    maxResults: 0,
    nextToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListComponents';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"owner":"","filters":[{"name":"","values":""}],"byName":false,"maxResults":0,"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListComponents',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "owner": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "byName": false,\n  "maxResults": 0,\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListComponents")
  .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/ListComponents',
  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({
  owner: '',
  filters: [{name: '', values: ''}],
  byName: false,
  maxResults: 0,
  nextToken: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListComponents',
  headers: {'content-type': 'application/json'},
  body: {
    owner: '',
    filters: [{name: '', values: ''}],
    byName: false,
    maxResults: 0,
    nextToken: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListComponents');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  owner: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  byName: false,
  maxResults: 0,
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListComponents',
  headers: {'content-type': 'application/json'},
  data: {
    owner: '',
    filters: [{name: '', values: ''}],
    byName: false,
    maxResults: 0,
    nextToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListComponents';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"owner":"","filters":[{"name":"","values":""}],"byName":false,"maxResults":0,"nextToken":""}'
};

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 = @{ @"owner": @"",
                              @"filters": @[ @{ @"name": @"", @"values": @"" } ],
                              @"byName": @NO,
                              @"maxResults": @0,
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListComponents"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListComponents" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListComponents",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'owner' => '',
    'filters' => [
        [
                'name' => '',
                'values' => ''
        ]
    ],
    'byName' => null,
    'maxResults' => 0,
    'nextToken' => ''
  ]),
  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}}/ListComponents', [
  'body' => '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListComponents');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'owner' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'byName' => null,
  'maxResults' => 0,
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'owner' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'byName' => null,
  'maxResults' => 0,
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListComponents');
$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}}/ListComponents' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListComponents' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListComponents", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListComponents"

payload = {
    "owner": "",
    "filters": [
        {
            "name": "",
            "values": ""
        }
    ],
    "byName": False,
    "maxResults": 0,
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListComponents"

payload <- "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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}}/ListComponents")

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  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListComponents') do |req|
  req.body = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListComponents";

    let payload = json!({
        "owner": "",
        "filters": (
            json!({
                "name": "",
                "values": ""
            })
        ),
        "byName": false,
        "maxResults": 0,
        "nextToken": ""
    });

    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}}/ListComponents \
  --header 'content-type: application/json' \
  --data '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": ""
}'
echo '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListComponents \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "owner": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "byName": false,\n  "maxResults": 0,\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListComponents
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "owner": "",
  "filters": [
    [
      "name": "",
      "values": ""
    ]
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListComponents")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListContainerRecipes
{{baseUrl}}/ListContainerRecipes
BODY json

{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListContainerRecipes");

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  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListContainerRecipes" {:content-type :json
                                                                 :form-params {:owner ""
                                                                               :filters [{:name ""
                                                                                          :values ""}]
                                                                               :maxResults 0
                                                                               :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListContainerRecipes"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListContainerRecipes"),
    Content = new StringContent("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListContainerRecipes");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListContainerRecipes"

	payload := strings.NewReader("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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/ListContainerRecipes HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 124

{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListContainerRecipes")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListContainerRecipes"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListContainerRecipes")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListContainerRecipes")
  .header("content-type", "application/json")
  .body("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  owner: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListContainerRecipes');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListContainerRecipes',
  headers: {'content-type': 'application/json'},
  data: {owner: '', filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListContainerRecipes';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"owner":"","filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListContainerRecipes',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "owner": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListContainerRecipes")
  .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/ListContainerRecipes',
  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({owner: '', filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListContainerRecipes',
  headers: {'content-type': 'application/json'},
  body: {owner: '', filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListContainerRecipes');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  owner: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListContainerRecipes',
  headers: {'content-type': 'application/json'},
  data: {owner: '', filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListContainerRecipes';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"owner":"","filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

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 = @{ @"owner": @"",
                              @"filters": @[ @{ @"name": @"", @"values": @"" } ],
                              @"maxResults": @0,
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListContainerRecipes"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListContainerRecipes" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListContainerRecipes",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'owner' => '',
    'filters' => [
        [
                'name' => '',
                'values' => ''
        ]
    ],
    'maxResults' => 0,
    'nextToken' => ''
  ]),
  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}}/ListContainerRecipes', [
  'body' => '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListContainerRecipes');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'owner' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'owner' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListContainerRecipes');
$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}}/ListContainerRecipes' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListContainerRecipes' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListContainerRecipes", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListContainerRecipes"

payload = {
    "owner": "",
    "filters": [
        {
            "name": "",
            "values": ""
        }
    ],
    "maxResults": 0,
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListContainerRecipes"

payload <- "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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}}/ListContainerRecipes")

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  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListContainerRecipes') do |req|
  req.body = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListContainerRecipes";

    let payload = json!({
        "owner": "",
        "filters": (
            json!({
                "name": "",
                "values": ""
            })
        ),
        "maxResults": 0,
        "nextToken": ""
    });

    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}}/ListContainerRecipes \
  --header 'content-type: application/json' \
  --data '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
echo '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListContainerRecipes \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "owner": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListContainerRecipes
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "owner": "",
  "filters": [
    [
      "name": "",
      "values": ""
    ]
  ],
  "maxResults": 0,
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListContainerRecipes")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListDistributionConfigurations
{{baseUrl}}/ListDistributionConfigurations
BODY json

{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListDistributionConfigurations");

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  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListDistributionConfigurations" {:content-type :json
                                                                           :form-params {:filters [{:name ""
                                                                                                    :values ""}]
                                                                                         :maxResults 0
                                                                                         :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListDistributionConfigurations"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListDistributionConfigurations"),
    Content = new StringContent("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListDistributionConfigurations");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListDistributionConfigurations"

	payload := strings.NewReader("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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/ListDistributionConfigurations HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 109

{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListDistributionConfigurations")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListDistributionConfigurations"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListDistributionConfigurations")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListDistributionConfigurations")
  .header("content-type", "application/json")
  .body("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListDistributionConfigurations');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListDistributionConfigurations',
  headers: {'content-type': 'application/json'},
  data: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListDistributionConfigurations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListDistributionConfigurations',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListDistributionConfigurations")
  .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/ListDistributionConfigurations',
  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({filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListDistributionConfigurations',
  headers: {'content-type': 'application/json'},
  body: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListDistributionConfigurations');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListDistributionConfigurations',
  headers: {'content-type': 'application/json'},
  data: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListDistributionConfigurations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

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 = @{ @"filters": @[ @{ @"name": @"", @"values": @"" } ],
                              @"maxResults": @0,
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListDistributionConfigurations"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListDistributionConfigurations" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListDistributionConfigurations",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'filters' => [
        [
                'name' => '',
                'values' => ''
        ]
    ],
    'maxResults' => 0,
    'nextToken' => ''
  ]),
  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}}/ListDistributionConfigurations', [
  'body' => '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListDistributionConfigurations');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListDistributionConfigurations');
$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}}/ListDistributionConfigurations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListDistributionConfigurations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListDistributionConfigurations", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListDistributionConfigurations"

payload = {
    "filters": [
        {
            "name": "",
            "values": ""
        }
    ],
    "maxResults": 0,
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListDistributionConfigurations"

payload <- "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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}}/ListDistributionConfigurations")

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  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListDistributionConfigurations') do |req|
  req.body = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListDistributionConfigurations";

    let payload = json!({
        "filters": (
            json!({
                "name": "",
                "values": ""
            })
        ),
        "maxResults": 0,
        "nextToken": ""
    });

    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}}/ListDistributionConfigurations \
  --header 'content-type: application/json' \
  --data '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
echo '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListDistributionConfigurations \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListDistributionConfigurations
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "filters": [
    [
      "name": "",
      "values": ""
    ]
  ],
  "maxResults": 0,
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListDistributionConfigurations")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListImageBuildVersions
{{baseUrl}}/ListImageBuildVersions
BODY json

{
  "imageVersionArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListImageBuildVersions");

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  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListImageBuildVersions" {:content-type :json
                                                                   :form-params {:imageVersionArn ""
                                                                                 :filters [{:name ""
                                                                                            :values ""}]
                                                                                 :maxResults 0
                                                                                 :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListImageBuildVersions"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListImageBuildVersions"),
    Content = new StringContent("{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListImageBuildVersions");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListImageBuildVersions"

	payload := strings.NewReader("{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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/ListImageBuildVersions HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 134

{
  "imageVersionArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListImageBuildVersions")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListImageBuildVersions"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListImageBuildVersions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListImageBuildVersions")
  .header("content-type", "application/json")
  .body("{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  imageVersionArn: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListImageBuildVersions');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageBuildVersions',
  headers: {'content-type': 'application/json'},
  data: {
    imageVersionArn: '',
    filters: [{name: '', values: ''}],
    maxResults: 0,
    nextToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListImageBuildVersions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"imageVersionArn":"","filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListImageBuildVersions',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "imageVersionArn": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListImageBuildVersions")
  .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/ListImageBuildVersions',
  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({
  imageVersionArn: '',
  filters: [{name: '', values: ''}],
  maxResults: 0,
  nextToken: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageBuildVersions',
  headers: {'content-type': 'application/json'},
  body: {
    imageVersionArn: '',
    filters: [{name: '', values: ''}],
    maxResults: 0,
    nextToken: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListImageBuildVersions');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  imageVersionArn: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageBuildVersions',
  headers: {'content-type': 'application/json'},
  data: {
    imageVersionArn: '',
    filters: [{name: '', values: ''}],
    maxResults: 0,
    nextToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListImageBuildVersions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"imageVersionArn":"","filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

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 = @{ @"imageVersionArn": @"",
                              @"filters": @[ @{ @"name": @"", @"values": @"" } ],
                              @"maxResults": @0,
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListImageBuildVersions"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListImageBuildVersions" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListImageBuildVersions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'imageVersionArn' => '',
    'filters' => [
        [
                'name' => '',
                'values' => ''
        ]
    ],
    'maxResults' => 0,
    'nextToken' => ''
  ]),
  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}}/ListImageBuildVersions', [
  'body' => '{
  "imageVersionArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListImageBuildVersions');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'imageVersionArn' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'imageVersionArn' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListImageBuildVersions');
$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}}/ListImageBuildVersions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "imageVersionArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListImageBuildVersions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "imageVersionArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListImageBuildVersions", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListImageBuildVersions"

payload = {
    "imageVersionArn": "",
    "filters": [
        {
            "name": "",
            "values": ""
        }
    ],
    "maxResults": 0,
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListImageBuildVersions"

payload <- "{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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}}/ListImageBuildVersions")

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  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListImageBuildVersions') do |req|
  req.body = "{\n  \"imageVersionArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListImageBuildVersions";

    let payload = json!({
        "imageVersionArn": "",
        "filters": (
            json!({
                "name": "",
                "values": ""
            })
        ),
        "maxResults": 0,
        "nextToken": ""
    });

    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}}/ListImageBuildVersions \
  --header 'content-type: application/json' \
  --data '{
  "imageVersionArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
echo '{
  "imageVersionArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListImageBuildVersions \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "imageVersionArn": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListImageBuildVersions
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "imageVersionArn": "",
  "filters": [
    [
      "name": "",
      "values": ""
    ]
  ],
  "maxResults": 0,
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListImageBuildVersions")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListImagePackages
{{baseUrl}}/ListImagePackages
BODY json

{
  "imageBuildVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListImagePackages");

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  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListImagePackages" {:content-type :json
                                                              :form-params {:imageBuildVersionArn ""
                                                                            :maxResults 0
                                                                            :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListImagePackages"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListImagePackages"),
    Content = new StringContent("{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListImagePackages");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListImagePackages"

	payload := strings.NewReader("{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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/ListImagePackages HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 70

{
  "imageBuildVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListImagePackages")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListImagePackages"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListImagePackages")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListImagePackages")
  .header("content-type", "application/json")
  .body("{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  imageBuildVersionArn: '',
  maxResults: 0,
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListImagePackages');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImagePackages',
  headers: {'content-type': 'application/json'},
  data: {imageBuildVersionArn: '', maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListImagePackages';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"imageBuildVersionArn":"","maxResults":0,"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListImagePackages',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "imageBuildVersionArn": "",\n  "maxResults": 0,\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListImagePackages")
  .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/ListImagePackages',
  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({imageBuildVersionArn: '', maxResults: 0, nextToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImagePackages',
  headers: {'content-type': 'application/json'},
  body: {imageBuildVersionArn: '', maxResults: 0, nextToken: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListImagePackages');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  imageBuildVersionArn: '',
  maxResults: 0,
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImagePackages',
  headers: {'content-type': 'application/json'},
  data: {imageBuildVersionArn: '', maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListImagePackages';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"imageBuildVersionArn":"","maxResults":0,"nextToken":""}'
};

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 = @{ @"imageBuildVersionArn": @"",
                              @"maxResults": @0,
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListImagePackages"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListImagePackages" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListImagePackages",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'imageBuildVersionArn' => '',
    'maxResults' => 0,
    'nextToken' => ''
  ]),
  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}}/ListImagePackages', [
  'body' => '{
  "imageBuildVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListImagePackages');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'imageBuildVersionArn' => '',
  'maxResults' => 0,
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'imageBuildVersionArn' => '',
  'maxResults' => 0,
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListImagePackages');
$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}}/ListImagePackages' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "imageBuildVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListImagePackages' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "imageBuildVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListImagePackages", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListImagePackages"

payload = {
    "imageBuildVersionArn": "",
    "maxResults": 0,
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListImagePackages"

payload <- "{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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}}/ListImagePackages")

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  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListImagePackages') do |req|
  req.body = "{\n  \"imageBuildVersionArn\": \"\",\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListImagePackages";

    let payload = json!({
        "imageBuildVersionArn": "",
        "maxResults": 0,
        "nextToken": ""
    });

    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}}/ListImagePackages \
  --header 'content-type: application/json' \
  --data '{
  "imageBuildVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}'
echo '{
  "imageBuildVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListImagePackages \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "imageBuildVersionArn": "",\n  "maxResults": 0,\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListImagePackages
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "imageBuildVersionArn": "",
  "maxResults": 0,
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListImagePackages")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListImagePipelineImages
{{baseUrl}}/ListImagePipelineImages
BODY json

{
  "imagePipelineArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListImagePipelineImages");

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  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListImagePipelineImages" {:content-type :json
                                                                    :form-params {:imagePipelineArn ""
                                                                                  :filters [{:name ""
                                                                                             :values ""}]
                                                                                  :maxResults 0
                                                                                  :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListImagePipelineImages"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListImagePipelineImages"),
    Content = new StringContent("{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListImagePipelineImages");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListImagePipelineImages"

	payload := strings.NewReader("{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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/ListImagePipelineImages HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 135

{
  "imagePipelineArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListImagePipelineImages")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListImagePipelineImages"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListImagePipelineImages")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListImagePipelineImages")
  .header("content-type", "application/json")
  .body("{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  imagePipelineArn: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListImagePipelineImages');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImagePipelineImages',
  headers: {'content-type': 'application/json'},
  data: {
    imagePipelineArn: '',
    filters: [{name: '', values: ''}],
    maxResults: 0,
    nextToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListImagePipelineImages';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"imagePipelineArn":"","filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListImagePipelineImages',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "imagePipelineArn": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListImagePipelineImages")
  .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/ListImagePipelineImages',
  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({
  imagePipelineArn: '',
  filters: [{name: '', values: ''}],
  maxResults: 0,
  nextToken: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImagePipelineImages',
  headers: {'content-type': 'application/json'},
  body: {
    imagePipelineArn: '',
    filters: [{name: '', values: ''}],
    maxResults: 0,
    nextToken: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListImagePipelineImages');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  imagePipelineArn: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImagePipelineImages',
  headers: {'content-type': 'application/json'},
  data: {
    imagePipelineArn: '',
    filters: [{name: '', values: ''}],
    maxResults: 0,
    nextToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListImagePipelineImages';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"imagePipelineArn":"","filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

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 = @{ @"imagePipelineArn": @"",
                              @"filters": @[ @{ @"name": @"", @"values": @"" } ],
                              @"maxResults": @0,
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListImagePipelineImages"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListImagePipelineImages" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListImagePipelineImages",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'imagePipelineArn' => '',
    'filters' => [
        [
                'name' => '',
                'values' => ''
        ]
    ],
    'maxResults' => 0,
    'nextToken' => ''
  ]),
  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}}/ListImagePipelineImages', [
  'body' => '{
  "imagePipelineArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListImagePipelineImages');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'imagePipelineArn' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'imagePipelineArn' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListImagePipelineImages');
$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}}/ListImagePipelineImages' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "imagePipelineArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListImagePipelineImages' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "imagePipelineArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListImagePipelineImages", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListImagePipelineImages"

payload = {
    "imagePipelineArn": "",
    "filters": [
        {
            "name": "",
            "values": ""
        }
    ],
    "maxResults": 0,
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListImagePipelineImages"

payload <- "{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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}}/ListImagePipelineImages")

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  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListImagePipelineImages') do |req|
  req.body = "{\n  \"imagePipelineArn\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListImagePipelineImages";

    let payload = json!({
        "imagePipelineArn": "",
        "filters": (
            json!({
                "name": "",
                "values": ""
            })
        ),
        "maxResults": 0,
        "nextToken": ""
    });

    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}}/ListImagePipelineImages \
  --header 'content-type: application/json' \
  --data '{
  "imagePipelineArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
echo '{
  "imagePipelineArn": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListImagePipelineImages \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "imagePipelineArn": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListImagePipelineImages
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "imagePipelineArn": "",
  "filters": [
    [
      "name": "",
      "values": ""
    ]
  ],
  "maxResults": 0,
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListImagePipelineImages")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListImagePipelines
{{baseUrl}}/ListImagePipelines
BODY json

{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListImagePipelines");

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  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListImagePipelines" {:content-type :json
                                                               :form-params {:filters [{:name ""
                                                                                        :values ""}]
                                                                             :maxResults 0
                                                                             :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListImagePipelines"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListImagePipelines"),
    Content = new StringContent("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListImagePipelines");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListImagePipelines"

	payload := strings.NewReader("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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/ListImagePipelines HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 109

{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListImagePipelines")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListImagePipelines"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListImagePipelines")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListImagePipelines")
  .header("content-type", "application/json")
  .body("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListImagePipelines');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImagePipelines',
  headers: {'content-type': 'application/json'},
  data: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListImagePipelines';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListImagePipelines',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListImagePipelines")
  .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/ListImagePipelines',
  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({filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImagePipelines',
  headers: {'content-type': 'application/json'},
  body: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListImagePipelines');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImagePipelines',
  headers: {'content-type': 'application/json'},
  data: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListImagePipelines';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

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 = @{ @"filters": @[ @{ @"name": @"", @"values": @"" } ],
                              @"maxResults": @0,
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListImagePipelines"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListImagePipelines" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListImagePipelines",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'filters' => [
        [
                'name' => '',
                'values' => ''
        ]
    ],
    'maxResults' => 0,
    'nextToken' => ''
  ]),
  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}}/ListImagePipelines', [
  'body' => '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListImagePipelines');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListImagePipelines');
$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}}/ListImagePipelines' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListImagePipelines' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListImagePipelines", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListImagePipelines"

payload = {
    "filters": [
        {
            "name": "",
            "values": ""
        }
    ],
    "maxResults": 0,
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListImagePipelines"

payload <- "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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}}/ListImagePipelines")

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  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListImagePipelines') do |req|
  req.body = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListImagePipelines";

    let payload = json!({
        "filters": (
            json!({
                "name": "",
                "values": ""
            })
        ),
        "maxResults": 0,
        "nextToken": ""
    });

    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}}/ListImagePipelines \
  --header 'content-type: application/json' \
  --data '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
echo '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListImagePipelines \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListImagePipelines
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "filters": [
    [
      "name": "",
      "values": ""
    ]
  ],
  "maxResults": 0,
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListImagePipelines")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListImageRecipes
{{baseUrl}}/ListImageRecipes
BODY json

{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListImageRecipes");

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  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListImageRecipes" {:content-type :json
                                                             :form-params {:owner ""
                                                                           :filters [{:name ""
                                                                                      :values ""}]
                                                                           :maxResults 0
                                                                           :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListImageRecipes"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListImageRecipes"),
    Content = new StringContent("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListImageRecipes");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListImageRecipes"

	payload := strings.NewReader("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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/ListImageRecipes HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 124

{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListImageRecipes")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListImageRecipes"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListImageRecipes")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListImageRecipes")
  .header("content-type", "application/json")
  .body("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  owner: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListImageRecipes');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageRecipes',
  headers: {'content-type': 'application/json'},
  data: {owner: '', filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListImageRecipes';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"owner":"","filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListImageRecipes',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "owner": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListImageRecipes")
  .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/ListImageRecipes',
  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({owner: '', filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageRecipes',
  headers: {'content-type': 'application/json'},
  body: {owner: '', filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListImageRecipes');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  owner: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageRecipes',
  headers: {'content-type': 'application/json'},
  data: {owner: '', filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListImageRecipes';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"owner":"","filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

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 = @{ @"owner": @"",
                              @"filters": @[ @{ @"name": @"", @"values": @"" } ],
                              @"maxResults": @0,
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListImageRecipes"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListImageRecipes" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListImageRecipes",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'owner' => '',
    'filters' => [
        [
                'name' => '',
                'values' => ''
        ]
    ],
    'maxResults' => 0,
    'nextToken' => ''
  ]),
  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}}/ListImageRecipes', [
  'body' => '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListImageRecipes');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'owner' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'owner' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListImageRecipes');
$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}}/ListImageRecipes' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListImageRecipes' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListImageRecipes", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListImageRecipes"

payload = {
    "owner": "",
    "filters": [
        {
            "name": "",
            "values": ""
        }
    ],
    "maxResults": 0,
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListImageRecipes"

payload <- "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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}}/ListImageRecipes")

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  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListImageRecipes') do |req|
  req.body = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListImageRecipes";

    let payload = json!({
        "owner": "",
        "filters": (
            json!({
                "name": "",
                "values": ""
            })
        ),
        "maxResults": 0,
        "nextToken": ""
    });

    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}}/ListImageRecipes \
  --header 'content-type: application/json' \
  --data '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
echo '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListImageRecipes \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "owner": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListImageRecipes
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "owner": "",
  "filters": [
    [
      "name": "",
      "values": ""
    ]
  ],
  "maxResults": 0,
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListImageRecipes")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListImageScanFindingAggregations
{{baseUrl}}/ListImageScanFindingAggregations
BODY json

{
  "filter": {
    "name": "",
    "values": ""
  },
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListImageScanFindingAggregations");

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  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListImageScanFindingAggregations" {:content-type :json
                                                                             :form-params {:filter {:name ""
                                                                                                    :values ""}
                                                                                           :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListImageScanFindingAggregations"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListImageScanFindingAggregations"),
    Content = new StringContent("{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListImageScanFindingAggregations");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListImageScanFindingAggregations"

	payload := strings.NewReader("{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\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/ListImageScanFindingAggregations HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 73

{
  "filter": {
    "name": "",
    "values": ""
  },
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListImageScanFindingAggregations")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListImageScanFindingAggregations"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListImageScanFindingAggregations")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListImageScanFindingAggregations")
  .header("content-type", "application/json")
  .body("{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  filter: {
    name: '',
    values: ''
  },
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListImageScanFindingAggregations');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageScanFindingAggregations',
  headers: {'content-type': 'application/json'},
  data: {filter: {name: '', values: ''}, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListImageScanFindingAggregations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filter":{"name":"","values":""},"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListImageScanFindingAggregations',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "filter": {\n    "name": "",\n    "values": ""\n  },\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListImageScanFindingAggregations")
  .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/ListImageScanFindingAggregations',
  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({filter: {name: '', values: ''}, nextToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageScanFindingAggregations',
  headers: {'content-type': 'application/json'},
  body: {filter: {name: '', values: ''}, nextToken: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListImageScanFindingAggregations');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  filter: {
    name: '',
    values: ''
  },
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageScanFindingAggregations',
  headers: {'content-type': 'application/json'},
  data: {filter: {name: '', values: ''}, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListImageScanFindingAggregations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filter":{"name":"","values":""},"nextToken":""}'
};

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 = @{ @"filter": @{ @"name": @"", @"values": @"" },
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListImageScanFindingAggregations"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListImageScanFindingAggregations" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListImageScanFindingAggregations",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'filter' => [
        'name' => '',
        'values' => ''
    ],
    'nextToken' => ''
  ]),
  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}}/ListImageScanFindingAggregations', [
  'body' => '{
  "filter": {
    "name": "",
    "values": ""
  },
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListImageScanFindingAggregations');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'filter' => [
    'name' => '',
    'values' => ''
  ],
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'filter' => [
    'name' => '',
    'values' => ''
  ],
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListImageScanFindingAggregations');
$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}}/ListImageScanFindingAggregations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "filter": {
    "name": "",
    "values": ""
  },
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListImageScanFindingAggregations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "filter": {
    "name": "",
    "values": ""
  },
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListImageScanFindingAggregations", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListImageScanFindingAggregations"

payload = {
    "filter": {
        "name": "",
        "values": ""
    },
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListImageScanFindingAggregations"

payload <- "{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\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}}/ListImageScanFindingAggregations")

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  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListImageScanFindingAggregations') do |req|
  req.body = "{\n  \"filter\": {\n    \"name\": \"\",\n    \"values\": \"\"\n  },\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListImageScanFindingAggregations";

    let payload = json!({
        "filter": json!({
            "name": "",
            "values": ""
        }),
        "nextToken": ""
    });

    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}}/ListImageScanFindingAggregations \
  --header 'content-type: application/json' \
  --data '{
  "filter": {
    "name": "",
    "values": ""
  },
  "nextToken": ""
}'
echo '{
  "filter": {
    "name": "",
    "values": ""
  },
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListImageScanFindingAggregations \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "filter": {\n    "name": "",\n    "values": ""\n  },\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListImageScanFindingAggregations
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "filter": [
    "name": "",
    "values": ""
  ],
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListImageScanFindingAggregations")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListImageScanFindings
{{baseUrl}}/ListImageScanFindings
BODY json

{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListImageScanFindings");

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  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListImageScanFindings" {:content-type :json
                                                                  :form-params {:filters [{:name ""
                                                                                           :values ""}]
                                                                                :maxResults 0
                                                                                :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListImageScanFindings"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListImageScanFindings"),
    Content = new StringContent("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListImageScanFindings");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListImageScanFindings"

	payload := strings.NewReader("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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/ListImageScanFindings HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 109

{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListImageScanFindings")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListImageScanFindings"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListImageScanFindings")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListImageScanFindings")
  .header("content-type", "application/json")
  .body("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListImageScanFindings');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageScanFindings',
  headers: {'content-type': 'application/json'},
  data: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListImageScanFindings';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListImageScanFindings',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListImageScanFindings")
  .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/ListImageScanFindings',
  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({filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageScanFindings',
  headers: {'content-type': 'application/json'},
  body: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListImageScanFindings');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImageScanFindings',
  headers: {'content-type': 'application/json'},
  data: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListImageScanFindings';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

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 = @{ @"filters": @[ @{ @"name": @"", @"values": @"" } ],
                              @"maxResults": @0,
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListImageScanFindings"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListImageScanFindings" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListImageScanFindings",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'filters' => [
        [
                'name' => '',
                'values' => ''
        ]
    ],
    'maxResults' => 0,
    'nextToken' => ''
  ]),
  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}}/ListImageScanFindings', [
  'body' => '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListImageScanFindings');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListImageScanFindings');
$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}}/ListImageScanFindings' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListImageScanFindings' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListImageScanFindings", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListImageScanFindings"

payload = {
    "filters": [
        {
            "name": "",
            "values": ""
        }
    ],
    "maxResults": 0,
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListImageScanFindings"

payload <- "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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}}/ListImageScanFindings")

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  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListImageScanFindings') do |req|
  req.body = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListImageScanFindings";

    let payload = json!({
        "filters": (
            json!({
                "name": "",
                "values": ""
            })
        ),
        "maxResults": 0,
        "nextToken": ""
    });

    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}}/ListImageScanFindings \
  --header 'content-type: application/json' \
  --data '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
echo '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListImageScanFindings \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListImageScanFindings
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "filters": [
    [
      "name": "",
      "values": ""
    ]
  ],
  "maxResults": 0,
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListImageScanFindings")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListImages
{{baseUrl}}/ListImages
BODY json

{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": "",
  "includeDeprecated": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListImages");

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  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": false\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListImages" {:content-type :json
                                                       :form-params {:owner ""
                                                                     :filters [{:name ""
                                                                                :values ""}]
                                                                     :byName false
                                                                     :maxResults 0
                                                                     :nextToken ""
                                                                     :includeDeprecated false}})
require "http/client"

url = "{{baseUrl}}/ListImages"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": 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}}/ListImages"),
    Content = new StringContent("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": 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}}/ListImages");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListImages"

	payload := strings.NewReader("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": 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/ListImages HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 173

{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": "",
  "includeDeprecated": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListImages")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListImages"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": 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  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListImages")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListImages")
  .header("content-type", "application/json")
  .body("{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": false\n}")
  .asString();
const data = JSON.stringify({
  owner: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  byName: false,
  maxResults: 0,
  nextToken: '',
  includeDeprecated: 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}}/ListImages');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImages',
  headers: {'content-type': 'application/json'},
  data: {
    owner: '',
    filters: [{name: '', values: ''}],
    byName: false,
    maxResults: 0,
    nextToken: '',
    includeDeprecated: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListImages';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"owner":"","filters":[{"name":"","values":""}],"byName":false,"maxResults":0,"nextToken":"","includeDeprecated":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}}/ListImages',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "owner": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "byName": false,\n  "maxResults": 0,\n  "nextToken": "",\n  "includeDeprecated": 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  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListImages")
  .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/ListImages',
  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({
  owner: '',
  filters: [{name: '', values: ''}],
  byName: false,
  maxResults: 0,
  nextToken: '',
  includeDeprecated: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListImages',
  headers: {'content-type': 'application/json'},
  body: {
    owner: '',
    filters: [{name: '', values: ''}],
    byName: false,
    maxResults: 0,
    nextToken: '',
    includeDeprecated: 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}}/ListImages');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  owner: '',
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  byName: false,
  maxResults: 0,
  nextToken: '',
  includeDeprecated: 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}}/ListImages',
  headers: {'content-type': 'application/json'},
  data: {
    owner: '',
    filters: [{name: '', values: ''}],
    byName: false,
    maxResults: 0,
    nextToken: '',
    includeDeprecated: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListImages';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"owner":"","filters":[{"name":"","values":""}],"byName":false,"maxResults":0,"nextToken":"","includeDeprecated":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 = @{ @"owner": @"",
                              @"filters": @[ @{ @"name": @"", @"values": @"" } ],
                              @"byName": @NO,
                              @"maxResults": @0,
                              @"nextToken": @"",
                              @"includeDeprecated": @NO };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListImages"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListImages" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListImages",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'owner' => '',
    'filters' => [
        [
                'name' => '',
                'values' => ''
        ]
    ],
    'byName' => null,
    'maxResults' => 0,
    'nextToken' => '',
    'includeDeprecated' => 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}}/ListImages', [
  'body' => '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": "",
  "includeDeprecated": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListImages');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'owner' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'byName' => null,
  'maxResults' => 0,
  'nextToken' => '',
  'includeDeprecated' => null
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'owner' => '',
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'byName' => null,
  'maxResults' => 0,
  'nextToken' => '',
  'includeDeprecated' => null
]));
$request->setRequestUrl('{{baseUrl}}/ListImages');
$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}}/ListImages' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": "",
  "includeDeprecated": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListImages' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": "",
  "includeDeprecated": false
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": false\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListImages", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListImages"

payload = {
    "owner": "",
    "filters": [
        {
            "name": "",
            "values": ""
        }
    ],
    "byName": False,
    "maxResults": 0,
    "nextToken": "",
    "includeDeprecated": False
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListImages"

payload <- "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": 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}}/ListImages")

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  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": 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/ListImages') do |req|
  req.body = "{\n  \"owner\": \"\",\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"byName\": false,\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"includeDeprecated\": false\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListImages";

    let payload = json!({
        "owner": "",
        "filters": (
            json!({
                "name": "",
                "values": ""
            })
        ),
        "byName": false,
        "maxResults": 0,
        "nextToken": "",
        "includeDeprecated": 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}}/ListImages \
  --header 'content-type: application/json' \
  --data '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": "",
  "includeDeprecated": false
}'
echo '{
  "owner": "",
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": "",
  "includeDeprecated": false
}' |  \
  http POST {{baseUrl}}/ListImages \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "owner": "",\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "byName": false,\n  "maxResults": 0,\n  "nextToken": "",\n  "includeDeprecated": false\n}' \
  --output-document \
  - {{baseUrl}}/ListImages
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "owner": "",
  "filters": [
    [
      "name": "",
      "values": ""
    ]
  ],
  "byName": false,
  "maxResults": 0,
  "nextToken": "",
  "includeDeprecated": false
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListImages")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListInfrastructureConfigurations
{{baseUrl}}/ListInfrastructureConfigurations
BODY json

{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListInfrastructureConfigurations");

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  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListInfrastructureConfigurations" {:content-type :json
                                                                             :form-params {:filters [{:name ""
                                                                                                      :values ""}]
                                                                                           :maxResults 0
                                                                                           :nextToken ""}})
require "http/client"

url = "{{baseUrl}}/ListInfrastructureConfigurations"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListInfrastructureConfigurations"),
    Content = new StringContent("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListInfrastructureConfigurations");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListInfrastructureConfigurations"

	payload := strings.NewReader("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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/ListInfrastructureConfigurations HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 109

{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListInfrastructureConfigurations")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListInfrastructureConfigurations"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListInfrastructureConfigurations")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListInfrastructureConfigurations")
  .header("content-type", "application/json")
  .body("{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListInfrastructureConfigurations');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListInfrastructureConfigurations',
  headers: {'content-type': 'application/json'},
  data: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListInfrastructureConfigurations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListInfrastructureConfigurations',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListInfrastructureConfigurations")
  .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/ListInfrastructureConfigurations',
  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({filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListInfrastructureConfigurations',
  headers: {'content-type': 'application/json'},
  body: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListInfrastructureConfigurations');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  filters: [
    {
      name: '',
      values: ''
    }
  ],
  maxResults: 0,
  nextToken: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListInfrastructureConfigurations',
  headers: {'content-type': 'application/json'},
  data: {filters: [{name: '', values: ''}], maxResults: 0, nextToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListInfrastructureConfigurations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filters":[{"name":"","values":""}],"maxResults":0,"nextToken":""}'
};

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 = @{ @"filters": @[ @{ @"name": @"", @"values": @"" } ],
                              @"maxResults": @0,
                              @"nextToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListInfrastructureConfigurations"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListInfrastructureConfigurations" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListInfrastructureConfigurations",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'filters' => [
        [
                'name' => '',
                'values' => ''
        ]
    ],
    'maxResults' => 0,
    'nextToken' => ''
  ]),
  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}}/ListInfrastructureConfigurations', [
  'body' => '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListInfrastructureConfigurations');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'filters' => [
    [
        'name' => '',
        'values' => ''
    ]
  ],
  'maxResults' => 0,
  'nextToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListInfrastructureConfigurations');
$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}}/ListInfrastructureConfigurations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListInfrastructureConfigurations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListInfrastructureConfigurations", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListInfrastructureConfigurations"

payload = {
    "filters": [
        {
            "name": "",
            "values": ""
        }
    ],
    "maxResults": 0,
    "nextToken": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListInfrastructureConfigurations"

payload <- "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\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}}/ListInfrastructureConfigurations")

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  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListInfrastructureConfigurations') do |req|
  req.body = "{\n  \"filters\": [\n    {\n      \"name\": \"\",\n      \"values\": \"\"\n    }\n  ],\n  \"maxResults\": 0,\n  \"nextToken\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListInfrastructureConfigurations";

    let payload = json!({
        "filters": (
            json!({
                "name": "",
                "values": ""
            })
        ),
        "maxResults": 0,
        "nextToken": ""
    });

    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}}/ListInfrastructureConfigurations \
  --header 'content-type: application/json' \
  --data '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}'
echo '{
  "filters": [
    {
      "name": "",
      "values": ""
    }
  ],
  "maxResults": 0,
  "nextToken": ""
}' |  \
  http POST {{baseUrl}}/ListInfrastructureConfigurations \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "filters": [\n    {\n      "name": "",\n      "values": ""\n    }\n  ],\n  "maxResults": 0,\n  "nextToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListInfrastructureConfigurations
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "filters": [
    [
      "name": "",
      "values": ""
    ]
  ],
  "maxResults": 0,
  "nextToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListInfrastructureConfigurations")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET ListTagsForResource
{{baseUrl}}/tags/:resourceArn
QUERY PARAMS

resourceArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/tags/:resourceArn");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/tags/:resourceArn")
require "http/client"

url = "{{baseUrl}}/tags/:resourceArn"

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}}/tags/:resourceArn"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/tags/:resourceArn");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/tags/:resourceArn"

	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/tags/:resourceArn HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/tags/:resourceArn")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/tags/:resourceArn"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/tags/:resourceArn")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/tags/:resourceArn")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/tags/:resourceArn');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/tags/:resourceArn'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/tags/:resourceArn';
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}}/tags/:resourceArn',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/tags/:resourceArn")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/tags/:resourceArn',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/tags/:resourceArn'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/tags/:resourceArn');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/tags/:resourceArn'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/tags/:resourceArn';
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}}/tags/:resourceArn"]
                                                       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}}/tags/:resourceArn" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/tags/:resourceArn",
  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}}/tags/:resourceArn');

echo $response->getBody();
setUrl('{{baseUrl}}/tags/:resourceArn');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/tags/:resourceArn');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/tags/:resourceArn' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/tags/:resourceArn' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/tags/:resourceArn")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/tags/:resourceArn"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/tags/:resourceArn"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/tags/:resourceArn")

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/tags/:resourceArn') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/tags/:resourceArn";

    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}}/tags/:resourceArn
http GET {{baseUrl}}/tags/:resourceArn
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/tags/:resourceArn
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/tags/:resourceArn")! 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 ListWorkflowExecutions
{{baseUrl}}/ListWorkflowExecutions
BODY json

{
  "maxResults": 0,
  "nextToken": "",
  "imageBuildVersionArn": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListWorkflowExecutions");

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  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListWorkflowExecutions" {:content-type :json
                                                                   :form-params {:maxResults 0
                                                                                 :nextToken ""
                                                                                 :imageBuildVersionArn ""}})
require "http/client"

url = "{{baseUrl}}/ListWorkflowExecutions"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListWorkflowExecutions"),
    Content = new StringContent("{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListWorkflowExecutions");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListWorkflowExecutions"

	payload := strings.NewReader("{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\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/ListWorkflowExecutions HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 70

{
  "maxResults": 0,
  "nextToken": "",
  "imageBuildVersionArn": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListWorkflowExecutions")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListWorkflowExecutions"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListWorkflowExecutions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListWorkflowExecutions")
  .header("content-type", "application/json")
  .body("{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  maxResults: 0,
  nextToken: '',
  imageBuildVersionArn: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListWorkflowExecutions');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListWorkflowExecutions',
  headers: {'content-type': 'application/json'},
  data: {maxResults: 0, nextToken: '', imageBuildVersionArn: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListWorkflowExecutions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"maxResults":0,"nextToken":"","imageBuildVersionArn":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListWorkflowExecutions',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "maxResults": 0,\n  "nextToken": "",\n  "imageBuildVersionArn": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListWorkflowExecutions")
  .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/ListWorkflowExecutions',
  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({maxResults: 0, nextToken: '', imageBuildVersionArn: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListWorkflowExecutions',
  headers: {'content-type': 'application/json'},
  body: {maxResults: 0, nextToken: '', imageBuildVersionArn: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListWorkflowExecutions');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  maxResults: 0,
  nextToken: '',
  imageBuildVersionArn: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListWorkflowExecutions',
  headers: {'content-type': 'application/json'},
  data: {maxResults: 0, nextToken: '', imageBuildVersionArn: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListWorkflowExecutions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"maxResults":0,"nextToken":"","imageBuildVersionArn":""}'
};

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 = @{ @"maxResults": @0,
                              @"nextToken": @"",
                              @"imageBuildVersionArn": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListWorkflowExecutions"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListWorkflowExecutions" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListWorkflowExecutions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'maxResults' => 0,
    'nextToken' => '',
    'imageBuildVersionArn' => ''
  ]),
  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}}/ListWorkflowExecutions', [
  'body' => '{
  "maxResults": 0,
  "nextToken": "",
  "imageBuildVersionArn": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListWorkflowExecutions');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'maxResults' => 0,
  'nextToken' => '',
  'imageBuildVersionArn' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'maxResults' => 0,
  'nextToken' => '',
  'imageBuildVersionArn' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListWorkflowExecutions');
$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}}/ListWorkflowExecutions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "maxResults": 0,
  "nextToken": "",
  "imageBuildVersionArn": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListWorkflowExecutions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "maxResults": 0,
  "nextToken": "",
  "imageBuildVersionArn": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListWorkflowExecutions", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListWorkflowExecutions"

payload = {
    "maxResults": 0,
    "nextToken": "",
    "imageBuildVersionArn": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListWorkflowExecutions"

payload <- "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\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}}/ListWorkflowExecutions")

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  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListWorkflowExecutions') do |req|
  req.body = "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"imageBuildVersionArn\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListWorkflowExecutions";

    let payload = json!({
        "maxResults": 0,
        "nextToken": "",
        "imageBuildVersionArn": ""
    });

    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}}/ListWorkflowExecutions \
  --header 'content-type: application/json' \
  --data '{
  "maxResults": 0,
  "nextToken": "",
  "imageBuildVersionArn": ""
}'
echo '{
  "maxResults": 0,
  "nextToken": "",
  "imageBuildVersionArn": ""
}' |  \
  http POST {{baseUrl}}/ListWorkflowExecutions \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "maxResults": 0,\n  "nextToken": "",\n  "imageBuildVersionArn": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListWorkflowExecutions
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "maxResults": 0,
  "nextToken": "",
  "imageBuildVersionArn": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListWorkflowExecutions")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ListWorkflowStepExecutions
{{baseUrl}}/ListWorkflowStepExecutions
BODY json

{
  "maxResults": 0,
  "nextToken": "",
  "workflowExecutionId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/ListWorkflowStepExecutions");

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  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/ListWorkflowStepExecutions" {:content-type :json
                                                                       :form-params {:maxResults 0
                                                                                     :nextToken ""
                                                                                     :workflowExecutionId ""}})
require "http/client"

url = "{{baseUrl}}/ListWorkflowStepExecutions"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/ListWorkflowStepExecutions"),
    Content = new StringContent("{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/ListWorkflowStepExecutions");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/ListWorkflowStepExecutions"

	payload := strings.NewReader("{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\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/ListWorkflowStepExecutions HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 69

{
  "maxResults": 0,
  "nextToken": "",
  "workflowExecutionId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/ListWorkflowStepExecutions")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/ListWorkflowStepExecutions"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/ListWorkflowStepExecutions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/ListWorkflowStepExecutions")
  .header("content-type", "application/json")
  .body("{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  maxResults: 0,
  nextToken: '',
  workflowExecutionId: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/ListWorkflowStepExecutions');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListWorkflowStepExecutions',
  headers: {'content-type': 'application/json'},
  data: {maxResults: 0, nextToken: '', workflowExecutionId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/ListWorkflowStepExecutions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"maxResults":0,"nextToken":"","workflowExecutionId":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/ListWorkflowStepExecutions',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "maxResults": 0,\n  "nextToken": "",\n  "workflowExecutionId": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/ListWorkflowStepExecutions")
  .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/ListWorkflowStepExecutions',
  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({maxResults: 0, nextToken: '', workflowExecutionId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListWorkflowStepExecutions',
  headers: {'content-type': 'application/json'},
  body: {maxResults: 0, nextToken: '', workflowExecutionId: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/ListWorkflowStepExecutions');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  maxResults: 0,
  nextToken: '',
  workflowExecutionId: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/ListWorkflowStepExecutions',
  headers: {'content-type': 'application/json'},
  data: {maxResults: 0, nextToken: '', workflowExecutionId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/ListWorkflowStepExecutions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"maxResults":0,"nextToken":"","workflowExecutionId":""}'
};

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 = @{ @"maxResults": @0,
                              @"nextToken": @"",
                              @"workflowExecutionId": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/ListWorkflowStepExecutions"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/ListWorkflowStepExecutions" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/ListWorkflowStepExecutions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'maxResults' => 0,
    'nextToken' => '',
    'workflowExecutionId' => ''
  ]),
  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}}/ListWorkflowStepExecutions', [
  'body' => '{
  "maxResults": 0,
  "nextToken": "",
  "workflowExecutionId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/ListWorkflowStepExecutions');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'maxResults' => 0,
  'nextToken' => '',
  'workflowExecutionId' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'maxResults' => 0,
  'nextToken' => '',
  'workflowExecutionId' => ''
]));
$request->setRequestUrl('{{baseUrl}}/ListWorkflowStepExecutions');
$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}}/ListWorkflowStepExecutions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "maxResults": 0,
  "nextToken": "",
  "workflowExecutionId": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/ListWorkflowStepExecutions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "maxResults": 0,
  "nextToken": "",
  "workflowExecutionId": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/ListWorkflowStepExecutions", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/ListWorkflowStepExecutions"

payload = {
    "maxResults": 0,
    "nextToken": "",
    "workflowExecutionId": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/ListWorkflowStepExecutions"

payload <- "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\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}}/ListWorkflowStepExecutions")

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  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/ListWorkflowStepExecutions') do |req|
  req.body = "{\n  \"maxResults\": 0,\n  \"nextToken\": \"\",\n  \"workflowExecutionId\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/ListWorkflowStepExecutions";

    let payload = json!({
        "maxResults": 0,
        "nextToken": "",
        "workflowExecutionId": ""
    });

    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}}/ListWorkflowStepExecutions \
  --header 'content-type: application/json' \
  --data '{
  "maxResults": 0,
  "nextToken": "",
  "workflowExecutionId": ""
}'
echo '{
  "maxResults": 0,
  "nextToken": "",
  "workflowExecutionId": ""
}' |  \
  http POST {{baseUrl}}/ListWorkflowStepExecutions \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "maxResults": 0,\n  "nextToken": "",\n  "workflowExecutionId": ""\n}' \
  --output-document \
  - {{baseUrl}}/ListWorkflowStepExecutions
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "maxResults": 0,
  "nextToken": "",
  "workflowExecutionId": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/ListWorkflowStepExecutions")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as 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 PutComponentPolicy
{{baseUrl}}/PutComponentPolicy
BODY json

{
  "componentArn": "",
  "policy": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/PutComponentPolicy");

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  \"componentArn\": \"\",\n  \"policy\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/PutComponentPolicy" {:content-type :json
                                                              :form-params {:componentArn ""
                                                                            :policy ""}})
require "http/client"

url = "{{baseUrl}}/PutComponentPolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\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}}/PutComponentPolicy"),
    Content = new StringContent("{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/PutComponentPolicy");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/PutComponentPolicy"

	payload := strings.NewReader("{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\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/PutComponentPolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 40

{
  "componentArn": "",
  "policy": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/PutComponentPolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/PutComponentPolicy"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/PutComponentPolicy")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/PutComponentPolicy")
  .header("content-type", "application/json")
  .body("{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  componentArn: '',
  policy: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/PutComponentPolicy');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/PutComponentPolicy',
  headers: {'content-type': 'application/json'},
  data: {componentArn: '', policy: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/PutComponentPolicy';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"componentArn":"","policy":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/PutComponentPolicy',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "componentArn": "",\n  "policy": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/PutComponentPolicy")
  .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/PutComponentPolicy',
  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({componentArn: '', policy: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/PutComponentPolicy',
  headers: {'content-type': 'application/json'},
  body: {componentArn: '', policy: ''},
  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}}/PutComponentPolicy');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  componentArn: '',
  policy: ''
});

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}}/PutComponentPolicy',
  headers: {'content-type': 'application/json'},
  data: {componentArn: '', policy: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/PutComponentPolicy';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"componentArn":"","policy":""}'
};

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 = @{ @"componentArn": @"",
                              @"policy": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/PutComponentPolicy"]
                                                       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}}/PutComponentPolicy" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/PutComponentPolicy",
  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([
    'componentArn' => '',
    'policy' => ''
  ]),
  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}}/PutComponentPolicy', [
  'body' => '{
  "componentArn": "",
  "policy": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/PutComponentPolicy');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'componentArn' => '',
  'policy' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'componentArn' => '',
  'policy' => ''
]));
$request->setRequestUrl('{{baseUrl}}/PutComponentPolicy');
$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}}/PutComponentPolicy' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "componentArn": "",
  "policy": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/PutComponentPolicy' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "componentArn": "",
  "policy": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/PutComponentPolicy", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/PutComponentPolicy"

payload = {
    "componentArn": "",
    "policy": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/PutComponentPolicy"

payload <- "{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\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}}/PutComponentPolicy")

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  \"componentArn\": \"\",\n  \"policy\": \"\"\n}"

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/PutComponentPolicy') do |req|
  req.body = "{\n  \"componentArn\": \"\",\n  \"policy\": \"\"\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}}/PutComponentPolicy";

    let payload = json!({
        "componentArn": "",
        "policy": ""
    });

    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}}/PutComponentPolicy \
  --header 'content-type: application/json' \
  --data '{
  "componentArn": "",
  "policy": ""
}'
echo '{
  "componentArn": "",
  "policy": ""
}' |  \
  http PUT {{baseUrl}}/PutComponentPolicy \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "componentArn": "",\n  "policy": ""\n}' \
  --output-document \
  - {{baseUrl}}/PutComponentPolicy
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "componentArn": "",
  "policy": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/PutComponentPolicy")! 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 PutContainerRecipePolicy
{{baseUrl}}/PutContainerRecipePolicy
BODY json

{
  "containerRecipeArn": "",
  "policy": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/PutContainerRecipePolicy");

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  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/PutContainerRecipePolicy" {:content-type :json
                                                                    :form-params {:containerRecipeArn ""
                                                                                  :policy ""}})
require "http/client"

url = "{{baseUrl}}/PutContainerRecipePolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\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}}/PutContainerRecipePolicy"),
    Content = new StringContent("{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/PutContainerRecipePolicy");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/PutContainerRecipePolicy"

	payload := strings.NewReader("{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\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/PutContainerRecipePolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 46

{
  "containerRecipeArn": "",
  "policy": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/PutContainerRecipePolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/PutContainerRecipePolicy"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/PutContainerRecipePolicy")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/PutContainerRecipePolicy")
  .header("content-type", "application/json")
  .body("{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  containerRecipeArn: '',
  policy: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/PutContainerRecipePolicy');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/PutContainerRecipePolicy',
  headers: {'content-type': 'application/json'},
  data: {containerRecipeArn: '', policy: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/PutContainerRecipePolicy';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"containerRecipeArn":"","policy":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/PutContainerRecipePolicy',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "containerRecipeArn": "",\n  "policy": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/PutContainerRecipePolicy")
  .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/PutContainerRecipePolicy',
  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({containerRecipeArn: '', policy: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/PutContainerRecipePolicy',
  headers: {'content-type': 'application/json'},
  body: {containerRecipeArn: '', policy: ''},
  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}}/PutContainerRecipePolicy');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  containerRecipeArn: '',
  policy: ''
});

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}}/PutContainerRecipePolicy',
  headers: {'content-type': 'application/json'},
  data: {containerRecipeArn: '', policy: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/PutContainerRecipePolicy';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"containerRecipeArn":"","policy":""}'
};

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 = @{ @"containerRecipeArn": @"",
                              @"policy": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/PutContainerRecipePolicy"]
                                                       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}}/PutContainerRecipePolicy" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/PutContainerRecipePolicy",
  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([
    'containerRecipeArn' => '',
    'policy' => ''
  ]),
  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}}/PutContainerRecipePolicy', [
  'body' => '{
  "containerRecipeArn": "",
  "policy": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/PutContainerRecipePolicy');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'containerRecipeArn' => '',
  'policy' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'containerRecipeArn' => '',
  'policy' => ''
]));
$request->setRequestUrl('{{baseUrl}}/PutContainerRecipePolicy');
$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}}/PutContainerRecipePolicy' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "containerRecipeArn": "",
  "policy": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/PutContainerRecipePolicy' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "containerRecipeArn": "",
  "policy": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/PutContainerRecipePolicy", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/PutContainerRecipePolicy"

payload = {
    "containerRecipeArn": "",
    "policy": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/PutContainerRecipePolicy"

payload <- "{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\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}}/PutContainerRecipePolicy")

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  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\n}"

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/PutContainerRecipePolicy') do |req|
  req.body = "{\n  \"containerRecipeArn\": \"\",\n  \"policy\": \"\"\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}}/PutContainerRecipePolicy";

    let payload = json!({
        "containerRecipeArn": "",
        "policy": ""
    });

    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}}/PutContainerRecipePolicy \
  --header 'content-type: application/json' \
  --data '{
  "containerRecipeArn": "",
  "policy": ""
}'
echo '{
  "containerRecipeArn": "",
  "policy": ""
}' |  \
  http PUT {{baseUrl}}/PutContainerRecipePolicy \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "containerRecipeArn": "",\n  "policy": ""\n}' \
  --output-document \
  - {{baseUrl}}/PutContainerRecipePolicy
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "containerRecipeArn": "",
  "policy": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/PutContainerRecipePolicy")! 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 PutImagePolicy
{{baseUrl}}/PutImagePolicy
BODY json

{
  "imageArn": "",
  "policy": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/PutImagePolicy");

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  \"imageArn\": \"\",\n  \"policy\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/PutImagePolicy" {:content-type :json
                                                          :form-params {:imageArn ""
                                                                        :policy ""}})
require "http/client"

url = "{{baseUrl}}/PutImagePolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\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}}/PutImagePolicy"),
    Content = new StringContent("{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/PutImagePolicy");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/PutImagePolicy"

	payload := strings.NewReader("{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\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/PutImagePolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 36

{
  "imageArn": "",
  "policy": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/PutImagePolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/PutImagePolicy"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/PutImagePolicy")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/PutImagePolicy")
  .header("content-type", "application/json")
  .body("{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  imageArn: '',
  policy: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/PutImagePolicy');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/PutImagePolicy',
  headers: {'content-type': 'application/json'},
  data: {imageArn: '', policy: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/PutImagePolicy';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"imageArn":"","policy":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/PutImagePolicy',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "imageArn": "",\n  "policy": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/PutImagePolicy")
  .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/PutImagePolicy',
  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({imageArn: '', policy: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/PutImagePolicy',
  headers: {'content-type': 'application/json'},
  body: {imageArn: '', policy: ''},
  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}}/PutImagePolicy');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  imageArn: '',
  policy: ''
});

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}}/PutImagePolicy',
  headers: {'content-type': 'application/json'},
  data: {imageArn: '', policy: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/PutImagePolicy';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"imageArn":"","policy":""}'
};

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 = @{ @"imageArn": @"",
                              @"policy": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/PutImagePolicy"]
                                                       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}}/PutImagePolicy" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/PutImagePolicy",
  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([
    'imageArn' => '',
    'policy' => ''
  ]),
  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}}/PutImagePolicy', [
  'body' => '{
  "imageArn": "",
  "policy": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/PutImagePolicy');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'imageArn' => '',
  'policy' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'imageArn' => '',
  'policy' => ''
]));
$request->setRequestUrl('{{baseUrl}}/PutImagePolicy');
$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}}/PutImagePolicy' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "imageArn": "",
  "policy": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/PutImagePolicy' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "imageArn": "",
  "policy": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/PutImagePolicy", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/PutImagePolicy"

payload = {
    "imageArn": "",
    "policy": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/PutImagePolicy"

payload <- "{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\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}}/PutImagePolicy")

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  \"imageArn\": \"\",\n  \"policy\": \"\"\n}"

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/PutImagePolicy') do |req|
  req.body = "{\n  \"imageArn\": \"\",\n  \"policy\": \"\"\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}}/PutImagePolicy";

    let payload = json!({
        "imageArn": "",
        "policy": ""
    });

    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}}/PutImagePolicy \
  --header 'content-type: application/json' \
  --data '{
  "imageArn": "",
  "policy": ""
}'
echo '{
  "imageArn": "",
  "policy": ""
}' |  \
  http PUT {{baseUrl}}/PutImagePolicy \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "imageArn": "",\n  "policy": ""\n}' \
  --output-document \
  - {{baseUrl}}/PutImagePolicy
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "imageArn": "",
  "policy": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/PutImagePolicy")! 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 PutImageRecipePolicy
{{baseUrl}}/PutImageRecipePolicy
BODY json

{
  "imageRecipeArn": "",
  "policy": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/PutImageRecipePolicy");

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  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/PutImageRecipePolicy" {:content-type :json
                                                                :form-params {:imageRecipeArn ""
                                                                              :policy ""}})
require "http/client"

url = "{{baseUrl}}/PutImageRecipePolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\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}}/PutImageRecipePolicy"),
    Content = new StringContent("{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/PutImageRecipePolicy");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/PutImageRecipePolicy"

	payload := strings.NewReader("{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\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/PutImageRecipePolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 42

{
  "imageRecipeArn": "",
  "policy": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/PutImageRecipePolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/PutImageRecipePolicy"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/PutImageRecipePolicy")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/PutImageRecipePolicy")
  .header("content-type", "application/json")
  .body("{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  imageRecipeArn: '',
  policy: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/PutImageRecipePolicy');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/PutImageRecipePolicy',
  headers: {'content-type': 'application/json'},
  data: {imageRecipeArn: '', policy: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/PutImageRecipePolicy';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"imageRecipeArn":"","policy":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/PutImageRecipePolicy',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "imageRecipeArn": "",\n  "policy": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/PutImageRecipePolicy")
  .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/PutImageRecipePolicy',
  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({imageRecipeArn: '', policy: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/PutImageRecipePolicy',
  headers: {'content-type': 'application/json'},
  body: {imageRecipeArn: '', policy: ''},
  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}}/PutImageRecipePolicy');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  imageRecipeArn: '',
  policy: ''
});

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}}/PutImageRecipePolicy',
  headers: {'content-type': 'application/json'},
  data: {imageRecipeArn: '', policy: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/PutImageRecipePolicy';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"imageRecipeArn":"","policy":""}'
};

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 = @{ @"imageRecipeArn": @"",
                              @"policy": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/PutImageRecipePolicy"]
                                                       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}}/PutImageRecipePolicy" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/PutImageRecipePolicy",
  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([
    'imageRecipeArn' => '',
    'policy' => ''
  ]),
  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}}/PutImageRecipePolicy', [
  'body' => '{
  "imageRecipeArn": "",
  "policy": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/PutImageRecipePolicy');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'imageRecipeArn' => '',
  'policy' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'imageRecipeArn' => '',
  'policy' => ''
]));
$request->setRequestUrl('{{baseUrl}}/PutImageRecipePolicy');
$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}}/PutImageRecipePolicy' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "imageRecipeArn": "",
  "policy": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/PutImageRecipePolicy' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "imageRecipeArn": "",
  "policy": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/PutImageRecipePolicy", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/PutImageRecipePolicy"

payload = {
    "imageRecipeArn": "",
    "policy": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/PutImageRecipePolicy"

payload <- "{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\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}}/PutImageRecipePolicy")

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  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\n}"

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/PutImageRecipePolicy') do |req|
  req.body = "{\n  \"imageRecipeArn\": \"\",\n  \"policy\": \"\"\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}}/PutImageRecipePolicy";

    let payload = json!({
        "imageRecipeArn": "",
        "policy": ""
    });

    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}}/PutImageRecipePolicy \
  --header 'content-type: application/json' \
  --data '{
  "imageRecipeArn": "",
  "policy": ""
}'
echo '{
  "imageRecipeArn": "",
  "policy": ""
}' |  \
  http PUT {{baseUrl}}/PutImageRecipePolicy \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "imageRecipeArn": "",\n  "policy": ""\n}' \
  --output-document \
  - {{baseUrl}}/PutImageRecipePolicy
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "imageRecipeArn": "",
  "policy": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/PutImageRecipePolicy")! 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 StartImagePipelineExecution
{{baseUrl}}/StartImagePipelineExecution
BODY json

{
  "imagePipelineArn": "",
  "clientToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/StartImagePipelineExecution");

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  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/StartImagePipelineExecution" {:content-type :json
                                                                       :form-params {:imagePipelineArn ""
                                                                                     :clientToken ""}})
require "http/client"

url = "{{baseUrl}}/StartImagePipelineExecution"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\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}}/StartImagePipelineExecution"),
    Content = new StringContent("{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/StartImagePipelineExecution");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/StartImagePipelineExecution"

	payload := strings.NewReader("{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\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/StartImagePipelineExecution HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 49

{
  "imagePipelineArn": "",
  "clientToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/StartImagePipelineExecution")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/StartImagePipelineExecution"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/StartImagePipelineExecution")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/StartImagePipelineExecution")
  .header("content-type", "application/json")
  .body("{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  imagePipelineArn: '',
  clientToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/StartImagePipelineExecution');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/StartImagePipelineExecution',
  headers: {'content-type': 'application/json'},
  data: {imagePipelineArn: '', clientToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/StartImagePipelineExecution';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"imagePipelineArn":"","clientToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/StartImagePipelineExecution',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "imagePipelineArn": "",\n  "clientToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/StartImagePipelineExecution")
  .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/StartImagePipelineExecution',
  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({imagePipelineArn: '', clientToken: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/StartImagePipelineExecution',
  headers: {'content-type': 'application/json'},
  body: {imagePipelineArn: '', clientToken: ''},
  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}}/StartImagePipelineExecution');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  imagePipelineArn: '',
  clientToken: ''
});

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}}/StartImagePipelineExecution',
  headers: {'content-type': 'application/json'},
  data: {imagePipelineArn: '', clientToken: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/StartImagePipelineExecution';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"imagePipelineArn":"","clientToken":""}'
};

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 = @{ @"imagePipelineArn": @"",
                              @"clientToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/StartImagePipelineExecution"]
                                                       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}}/StartImagePipelineExecution" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/StartImagePipelineExecution",
  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([
    'imagePipelineArn' => '',
    'clientToken' => ''
  ]),
  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}}/StartImagePipelineExecution', [
  'body' => '{
  "imagePipelineArn": "",
  "clientToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/StartImagePipelineExecution');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'imagePipelineArn' => '',
  'clientToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'imagePipelineArn' => '',
  'clientToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/StartImagePipelineExecution');
$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}}/StartImagePipelineExecution' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "imagePipelineArn": "",
  "clientToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/StartImagePipelineExecution' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "imagePipelineArn": "",
  "clientToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/StartImagePipelineExecution", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/StartImagePipelineExecution"

payload = {
    "imagePipelineArn": "",
    "clientToken": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/StartImagePipelineExecution"

payload <- "{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\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}}/StartImagePipelineExecution")

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  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\n}"

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/StartImagePipelineExecution') do |req|
  req.body = "{\n  \"imagePipelineArn\": \"\",\n  \"clientToken\": \"\"\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}}/StartImagePipelineExecution";

    let payload = json!({
        "imagePipelineArn": "",
        "clientToken": ""
    });

    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}}/StartImagePipelineExecution \
  --header 'content-type: application/json' \
  --data '{
  "imagePipelineArn": "",
  "clientToken": ""
}'
echo '{
  "imagePipelineArn": "",
  "clientToken": ""
}' |  \
  http PUT {{baseUrl}}/StartImagePipelineExecution \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "imagePipelineArn": "",\n  "clientToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/StartImagePipelineExecution
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "imagePipelineArn": "",
  "clientToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/StartImagePipelineExecution")! 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 TagResource
{{baseUrl}}/tags/:resourceArn
QUERY PARAMS

resourceArn
BODY json

{
  "tags": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/tags/:resourceArn");

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  \"tags\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/tags/:resourceArn" {:content-type :json
                                                              :form-params {:tags {}}})
require "http/client"

url = "{{baseUrl}}/tags/:resourceArn"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"tags\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/tags/:resourceArn"),
    Content = new StringContent("{\n  \"tags\": {}\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/tags/:resourceArn");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"tags\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/tags/:resourceArn"

	payload := strings.NewReader("{\n  \"tags\": {}\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/tags/:resourceArn HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 16

{
  "tags": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/tags/:resourceArn")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"tags\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/tags/:resourceArn"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"tags\": {}\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"tags\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/tags/:resourceArn")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/tags/:resourceArn")
  .header("content-type", "application/json")
  .body("{\n  \"tags\": {}\n}")
  .asString();
const data = JSON.stringify({
  tags: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/tags/:resourceArn');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/tags/:resourceArn',
  headers: {'content-type': 'application/json'},
  data: {tags: {}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/tags/:resourceArn';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"tags":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/tags/:resourceArn',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "tags": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"tags\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/tags/:resourceArn")
  .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/tags/:resourceArn',
  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({tags: {}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/tags/:resourceArn',
  headers: {'content-type': 'application/json'},
  body: {tags: {}},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/tags/:resourceArn');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  tags: {}
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/tags/:resourceArn',
  headers: {'content-type': 'application/json'},
  data: {tags: {}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/tags/:resourceArn';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"tags":{}}'
};

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 = @{ @"tags": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/tags/:resourceArn"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/tags/:resourceArn" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"tags\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/tags/:resourceArn",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'tags' => [
        
    ]
  ]),
  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}}/tags/:resourceArn', [
  'body' => '{
  "tags": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/tags/:resourceArn');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'tags' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'tags' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/tags/:resourceArn');
$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}}/tags/:resourceArn' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "tags": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/tags/:resourceArn' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "tags": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"tags\": {}\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/tags/:resourceArn", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/tags/:resourceArn"

payload = { "tags": {} }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/tags/:resourceArn"

payload <- "{\n  \"tags\": {}\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}}/tags/:resourceArn")

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  \"tags\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/tags/:resourceArn') do |req|
  req.body = "{\n  \"tags\": {}\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/tags/:resourceArn";

    let payload = json!({"tags": 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}}/tags/:resourceArn \
  --header 'content-type: application/json' \
  --data '{
  "tags": {}
}'
echo '{
  "tags": {}
}' |  \
  http POST {{baseUrl}}/tags/:resourceArn \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "tags": {}\n}' \
  --output-document \
  - {{baseUrl}}/tags/:resourceArn
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["tags": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/tags/:resourceArn")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as 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 UntagResource
{{baseUrl}}/tags/:resourceArn#tagKeys
QUERY PARAMS

tagKeys
resourceArn
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/tags/:resourceArn#tagKeys" {:query-params {:tagKeys ""}})
require "http/client"

url = "{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys"

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}}/tags/:resourceArn?tagKeys=#tagKeys"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys"

	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/tags/:resourceArn?tagKeys= HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys"))
    .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}}/tags/:resourceArn?tagKeys=#tagKeys")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys")
  .asString();
const 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}}/tags/:resourceArn?tagKeys=#tagKeys');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/tags/:resourceArn#tagKeys',
  params: {tagKeys: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys';
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}}/tags/:resourceArn?tagKeys=#tagKeys',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/tags/:resourceArn?tagKeys=',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/tags/:resourceArn#tagKeys',
  qs: {tagKeys: ''}
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/tags/:resourceArn#tagKeys');

req.query({
  tagKeys: ''
});

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}}/tags/:resourceArn#tagKeys',
  params: {tagKeys: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys';
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}}/tags/:resourceArn?tagKeys=#tagKeys"]
                                                       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}}/tags/:resourceArn?tagKeys=#tagKeys" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys",
  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}}/tags/:resourceArn?tagKeys=#tagKeys');

echo $response->getBody();
setUrl('{{baseUrl}}/tags/:resourceArn#tagKeys');
$request->setMethod(HTTP_METH_DELETE);

$request->setQueryData([
  'tagKeys' => ''
]);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/tags/:resourceArn#tagKeys');
$request->setRequestMethod('DELETE');
$request->setQuery(new http\QueryString([
  'tagKeys' => ''
]));

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/tags/:resourceArn?tagKeys=")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/tags/:resourceArn#tagKeys"

querystring = {"tagKeys":""}

response = requests.delete(url, params=querystring)

print(response.json())
library(httr)

url <- "{{baseUrl}}/tags/:resourceArn#tagKeys"

queryString <- list(tagKeys = "")

response <- VERB("DELETE", url, query = queryString, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys")

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/tags/:resourceArn') do |req|
  req.params['tagKeys'] = ''
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/tags/:resourceArn#tagKeys";

    let querystring = [
        ("tagKeys", ""),
    ];

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .query(&querystring)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url '{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys'
http DELETE '{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys'
wget --quiet \
  --method DELETE \
  --output-document \
  - '{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys'
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/tags/:resourceArn?tagKeys=#tagKeys")! 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 UpdateDistributionConfiguration
{{baseUrl}}/UpdateDistributionConfiguration
BODY json

{
  "distributionConfigurationArn": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "clientToken": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/UpdateDistributionConfiguration");

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  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/UpdateDistributionConfiguration" {:content-type :json
                                                                           :form-params {:distributionConfigurationArn ""
                                                                                         :description ""
                                                                                         :distributions [{:region ""
                                                                                                          :amiDistributionConfiguration ""
                                                                                                          :containerDistributionConfiguration ""
                                                                                                          :licenseConfigurationArns ""
                                                                                                          :launchTemplateConfigurations ""
                                                                                                          :s3ExportConfiguration ""
                                                                                                          :fastLaunchConfigurations ""}]
                                                                                         :clientToken ""}})
require "http/client"

url = "{{baseUrl}}/UpdateDistributionConfiguration"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\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}}/UpdateDistributionConfiguration"),
    Content = new StringContent("{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/UpdateDistributionConfiguration");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/UpdateDistributionConfiguration"

	payload := strings.NewReader("{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\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/UpdateDistributionConfiguration HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 382

{
  "distributionConfigurationArn": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "clientToken": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/UpdateDistributionConfiguration")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/UpdateDistributionConfiguration"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/UpdateDistributionConfiguration")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/UpdateDistributionConfiguration")
  .header("content-type", "application/json")
  .body("{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  distributionConfigurationArn: '',
  description: '',
  distributions: [
    {
      region: '',
      amiDistributionConfiguration: '',
      containerDistributionConfiguration: '',
      licenseConfigurationArns: '',
      launchTemplateConfigurations: '',
      s3ExportConfiguration: '',
      fastLaunchConfigurations: ''
    }
  ],
  clientToken: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/UpdateDistributionConfiguration');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/UpdateDistributionConfiguration',
  headers: {'content-type': 'application/json'},
  data: {
    distributionConfigurationArn: '',
    description: '',
    distributions: [
      {
        region: '',
        amiDistributionConfiguration: '',
        containerDistributionConfiguration: '',
        licenseConfigurationArns: '',
        launchTemplateConfigurations: '',
        s3ExportConfiguration: '',
        fastLaunchConfigurations: ''
      }
    ],
    clientToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/UpdateDistributionConfiguration';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"distributionConfigurationArn":"","description":"","distributions":[{"region":"","amiDistributionConfiguration":"","containerDistributionConfiguration":"","licenseConfigurationArns":"","launchTemplateConfigurations":"","s3ExportConfiguration":"","fastLaunchConfigurations":""}],"clientToken":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/UpdateDistributionConfiguration',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "distributionConfigurationArn": "",\n  "description": "",\n  "distributions": [\n    {\n      "region": "",\n      "amiDistributionConfiguration": "",\n      "containerDistributionConfiguration": "",\n      "licenseConfigurationArns": "",\n      "launchTemplateConfigurations": "",\n      "s3ExportConfiguration": "",\n      "fastLaunchConfigurations": ""\n    }\n  ],\n  "clientToken": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/UpdateDistributionConfiguration")
  .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/UpdateDistributionConfiguration',
  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({
  distributionConfigurationArn: '',
  description: '',
  distributions: [
    {
      region: '',
      amiDistributionConfiguration: '',
      containerDistributionConfiguration: '',
      licenseConfigurationArns: '',
      launchTemplateConfigurations: '',
      s3ExportConfiguration: '',
      fastLaunchConfigurations: ''
    }
  ],
  clientToken: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/UpdateDistributionConfiguration',
  headers: {'content-type': 'application/json'},
  body: {
    distributionConfigurationArn: '',
    description: '',
    distributions: [
      {
        region: '',
        amiDistributionConfiguration: '',
        containerDistributionConfiguration: '',
        licenseConfigurationArns: '',
        launchTemplateConfigurations: '',
        s3ExportConfiguration: '',
        fastLaunchConfigurations: ''
      }
    ],
    clientToken: ''
  },
  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}}/UpdateDistributionConfiguration');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  distributionConfigurationArn: '',
  description: '',
  distributions: [
    {
      region: '',
      amiDistributionConfiguration: '',
      containerDistributionConfiguration: '',
      licenseConfigurationArns: '',
      launchTemplateConfigurations: '',
      s3ExportConfiguration: '',
      fastLaunchConfigurations: ''
    }
  ],
  clientToken: ''
});

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}}/UpdateDistributionConfiguration',
  headers: {'content-type': 'application/json'},
  data: {
    distributionConfigurationArn: '',
    description: '',
    distributions: [
      {
        region: '',
        amiDistributionConfiguration: '',
        containerDistributionConfiguration: '',
        licenseConfigurationArns: '',
        launchTemplateConfigurations: '',
        s3ExportConfiguration: '',
        fastLaunchConfigurations: ''
      }
    ],
    clientToken: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/UpdateDistributionConfiguration';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"distributionConfigurationArn":"","description":"","distributions":[{"region":"","amiDistributionConfiguration":"","containerDistributionConfiguration":"","licenseConfigurationArns":"","launchTemplateConfigurations":"","s3ExportConfiguration":"","fastLaunchConfigurations":""}],"clientToken":""}'
};

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 = @{ @"distributionConfigurationArn": @"",
                              @"description": @"",
                              @"distributions": @[ @{ @"region": @"", @"amiDistributionConfiguration": @"", @"containerDistributionConfiguration": @"", @"licenseConfigurationArns": @"", @"launchTemplateConfigurations": @"", @"s3ExportConfiguration": @"", @"fastLaunchConfigurations": @"" } ],
                              @"clientToken": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/UpdateDistributionConfiguration"]
                                                       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}}/UpdateDistributionConfiguration" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/UpdateDistributionConfiguration",
  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([
    'distributionConfigurationArn' => '',
    'description' => '',
    'distributions' => [
        [
                'region' => '',
                'amiDistributionConfiguration' => '',
                'containerDistributionConfiguration' => '',
                'licenseConfigurationArns' => '',
                'launchTemplateConfigurations' => '',
                's3ExportConfiguration' => '',
                'fastLaunchConfigurations' => ''
        ]
    ],
    'clientToken' => ''
  ]),
  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}}/UpdateDistributionConfiguration', [
  'body' => '{
  "distributionConfigurationArn": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "clientToken": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/UpdateDistributionConfiguration');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'distributionConfigurationArn' => '',
  'description' => '',
  'distributions' => [
    [
        'region' => '',
        'amiDistributionConfiguration' => '',
        'containerDistributionConfiguration' => '',
        'licenseConfigurationArns' => '',
        'launchTemplateConfigurations' => '',
        's3ExportConfiguration' => '',
        'fastLaunchConfigurations' => ''
    ]
  ],
  'clientToken' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'distributionConfigurationArn' => '',
  'description' => '',
  'distributions' => [
    [
        'region' => '',
        'amiDistributionConfiguration' => '',
        'containerDistributionConfiguration' => '',
        'licenseConfigurationArns' => '',
        'launchTemplateConfigurations' => '',
        's3ExportConfiguration' => '',
        'fastLaunchConfigurations' => ''
    ]
  ],
  'clientToken' => ''
]));
$request->setRequestUrl('{{baseUrl}}/UpdateDistributionConfiguration');
$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}}/UpdateDistributionConfiguration' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "distributionConfigurationArn": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "clientToken": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/UpdateDistributionConfiguration' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "distributionConfigurationArn": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "clientToken": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/UpdateDistributionConfiguration", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/UpdateDistributionConfiguration"

payload = {
    "distributionConfigurationArn": "",
    "description": "",
    "distributions": [
        {
            "region": "",
            "amiDistributionConfiguration": "",
            "containerDistributionConfiguration": "",
            "licenseConfigurationArns": "",
            "launchTemplateConfigurations": "",
            "s3ExportConfiguration": "",
            "fastLaunchConfigurations": ""
        }
    ],
    "clientToken": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/UpdateDistributionConfiguration"

payload <- "{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\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}}/UpdateDistributionConfiguration")

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  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\n}"

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/UpdateDistributionConfiguration') do |req|
  req.body = "{\n  \"distributionConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"distributions\": [\n    {\n      \"region\": \"\",\n      \"amiDistributionConfiguration\": \"\",\n      \"containerDistributionConfiguration\": \"\",\n      \"licenseConfigurationArns\": \"\",\n      \"launchTemplateConfigurations\": \"\",\n      \"s3ExportConfiguration\": \"\",\n      \"fastLaunchConfigurations\": \"\"\n    }\n  ],\n  \"clientToken\": \"\"\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}}/UpdateDistributionConfiguration";

    let payload = json!({
        "distributionConfigurationArn": "",
        "description": "",
        "distributions": (
            json!({
                "region": "",
                "amiDistributionConfiguration": "",
                "containerDistributionConfiguration": "",
                "licenseConfigurationArns": "",
                "launchTemplateConfigurations": "",
                "s3ExportConfiguration": "",
                "fastLaunchConfigurations": ""
            })
        ),
        "clientToken": ""
    });

    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}}/UpdateDistributionConfiguration \
  --header 'content-type: application/json' \
  --data '{
  "distributionConfigurationArn": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "clientToken": ""
}'
echo '{
  "distributionConfigurationArn": "",
  "description": "",
  "distributions": [
    {
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    }
  ],
  "clientToken": ""
}' |  \
  http PUT {{baseUrl}}/UpdateDistributionConfiguration \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "distributionConfigurationArn": "",\n  "description": "",\n  "distributions": [\n    {\n      "region": "",\n      "amiDistributionConfiguration": "",\n      "containerDistributionConfiguration": "",\n      "licenseConfigurationArns": "",\n      "launchTemplateConfigurations": "",\n      "s3ExportConfiguration": "",\n      "fastLaunchConfigurations": ""\n    }\n  ],\n  "clientToken": ""\n}' \
  --output-document \
  - {{baseUrl}}/UpdateDistributionConfiguration
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "distributionConfigurationArn": "",
  "description": "",
  "distributions": [
    [
      "region": "",
      "amiDistributionConfiguration": "",
      "containerDistributionConfiguration": "",
      "licenseConfigurationArns": "",
      "launchTemplateConfigurations": "",
      "s3ExportConfiguration": "",
      "fastLaunchConfigurations": ""
    ]
  ],
  "clientToken": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/UpdateDistributionConfiguration")! 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 UpdateImagePipeline
{{baseUrl}}/UpdateImagePipeline
BODY json

{
  "imagePipelineArn": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/UpdateImagePipeline");

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  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/UpdateImagePipeline" {:content-type :json
                                                               :form-params {:imagePipelineArn ""
                                                                             :description ""
                                                                             :imageRecipeArn ""
                                                                             :containerRecipeArn ""
                                                                             :infrastructureConfigurationArn ""
                                                                             :distributionConfigurationArn ""
                                                                             :imageTestsConfiguration {:imageTestsEnabled ""
                                                                                                       :timeoutMinutes ""}
                                                                             :enhancedImageMetadataEnabled false
                                                                             :schedule {:scheduleExpression ""
                                                                                        :timezone ""
                                                                                        :pipelineExecutionStartCondition ""}
                                                                             :status ""
                                                                             :clientToken ""
                                                                             :imageScanningConfiguration {:imageScanningEnabled ""
                                                                                                          :ecrConfiguration ""}}})
require "http/client"

url = "{{baseUrl}}/UpdateImagePipeline"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/UpdateImagePipeline"),
    Content = new StringContent("{\n  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/UpdateImagePipeline");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/UpdateImagePipeline"

	payload := strings.NewReader("{\n  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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/UpdateImagePipeline HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 558

{
  "imagePipelineArn": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/UpdateImagePipeline")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/UpdateImagePipeline"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/UpdateImagePipeline")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/UpdateImagePipeline")
  .header("content-type", "application/json")
  .body("{\n  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  imagePipelineArn: '',
  description: '',
  imageRecipeArn: '',
  containerRecipeArn: '',
  infrastructureConfigurationArn: '',
  distributionConfigurationArn: '',
  imageTestsConfiguration: {
    imageTestsEnabled: '',
    timeoutMinutes: ''
  },
  enhancedImageMetadataEnabled: false,
  schedule: {
    scheduleExpression: '',
    timezone: '',
    pipelineExecutionStartCondition: ''
  },
  status: '',
  clientToken: '',
  imageScanningConfiguration: {
    imageScanningEnabled: '',
    ecrConfiguration: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/UpdateImagePipeline');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/UpdateImagePipeline',
  headers: {'content-type': 'application/json'},
  data: {
    imagePipelineArn: '',
    description: '',
    imageRecipeArn: '',
    containerRecipeArn: '',
    infrastructureConfigurationArn: '',
    distributionConfigurationArn: '',
    imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
    enhancedImageMetadataEnabled: false,
    schedule: {scheduleExpression: '', timezone: '', pipelineExecutionStartCondition: ''},
    status: '',
    clientToken: '',
    imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/UpdateImagePipeline';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"imagePipelineArn":"","description":"","imageRecipeArn":"","containerRecipeArn":"","infrastructureConfigurationArn":"","distributionConfigurationArn":"","imageTestsConfiguration":{"imageTestsEnabled":"","timeoutMinutes":""},"enhancedImageMetadataEnabled":false,"schedule":{"scheduleExpression":"","timezone":"","pipelineExecutionStartCondition":""},"status":"","clientToken":"","imageScanningConfiguration":{"imageScanningEnabled":"","ecrConfiguration":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/UpdateImagePipeline',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "imagePipelineArn": "",\n  "description": "",\n  "imageRecipeArn": "",\n  "containerRecipeArn": "",\n  "infrastructureConfigurationArn": "",\n  "distributionConfigurationArn": "",\n  "imageTestsConfiguration": {\n    "imageTestsEnabled": "",\n    "timeoutMinutes": ""\n  },\n  "enhancedImageMetadataEnabled": false,\n  "schedule": {\n    "scheduleExpression": "",\n    "timezone": "",\n    "pipelineExecutionStartCondition": ""\n  },\n  "status": "",\n  "clientToken": "",\n  "imageScanningConfiguration": {\n    "imageScanningEnabled": "",\n    "ecrConfiguration": ""\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  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/UpdateImagePipeline")
  .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/UpdateImagePipeline',
  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({
  imagePipelineArn: '',
  description: '',
  imageRecipeArn: '',
  containerRecipeArn: '',
  infrastructureConfigurationArn: '',
  distributionConfigurationArn: '',
  imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
  enhancedImageMetadataEnabled: false,
  schedule: {scheduleExpression: '', timezone: '', pipelineExecutionStartCondition: ''},
  status: '',
  clientToken: '',
  imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/UpdateImagePipeline',
  headers: {'content-type': 'application/json'},
  body: {
    imagePipelineArn: '',
    description: '',
    imageRecipeArn: '',
    containerRecipeArn: '',
    infrastructureConfigurationArn: '',
    distributionConfigurationArn: '',
    imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
    enhancedImageMetadataEnabled: false,
    schedule: {scheduleExpression: '', timezone: '', pipelineExecutionStartCondition: ''},
    status: '',
    clientToken: '',
    imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
  },
  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}}/UpdateImagePipeline');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  imagePipelineArn: '',
  description: '',
  imageRecipeArn: '',
  containerRecipeArn: '',
  infrastructureConfigurationArn: '',
  distributionConfigurationArn: '',
  imageTestsConfiguration: {
    imageTestsEnabled: '',
    timeoutMinutes: ''
  },
  enhancedImageMetadataEnabled: false,
  schedule: {
    scheduleExpression: '',
    timezone: '',
    pipelineExecutionStartCondition: ''
  },
  status: '',
  clientToken: '',
  imageScanningConfiguration: {
    imageScanningEnabled: '',
    ecrConfiguration: ''
  }
});

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}}/UpdateImagePipeline',
  headers: {'content-type': 'application/json'},
  data: {
    imagePipelineArn: '',
    description: '',
    imageRecipeArn: '',
    containerRecipeArn: '',
    infrastructureConfigurationArn: '',
    distributionConfigurationArn: '',
    imageTestsConfiguration: {imageTestsEnabled: '', timeoutMinutes: ''},
    enhancedImageMetadataEnabled: false,
    schedule: {scheduleExpression: '', timezone: '', pipelineExecutionStartCondition: ''},
    status: '',
    clientToken: '',
    imageScanningConfiguration: {imageScanningEnabled: '', ecrConfiguration: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/UpdateImagePipeline';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"imagePipelineArn":"","description":"","imageRecipeArn":"","containerRecipeArn":"","infrastructureConfigurationArn":"","distributionConfigurationArn":"","imageTestsConfiguration":{"imageTestsEnabled":"","timeoutMinutes":""},"enhancedImageMetadataEnabled":false,"schedule":{"scheduleExpression":"","timezone":"","pipelineExecutionStartCondition":""},"status":"","clientToken":"","imageScanningConfiguration":{"imageScanningEnabled":"","ecrConfiguration":""}}'
};

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 = @{ @"imagePipelineArn": @"",
                              @"description": @"",
                              @"imageRecipeArn": @"",
                              @"containerRecipeArn": @"",
                              @"infrastructureConfigurationArn": @"",
                              @"distributionConfigurationArn": @"",
                              @"imageTestsConfiguration": @{ @"imageTestsEnabled": @"", @"timeoutMinutes": @"" },
                              @"enhancedImageMetadataEnabled": @NO,
                              @"schedule": @{ @"scheduleExpression": @"", @"timezone": @"", @"pipelineExecutionStartCondition": @"" },
                              @"status": @"",
                              @"clientToken": @"",
                              @"imageScanningConfiguration": @{ @"imageScanningEnabled": @"", @"ecrConfiguration": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/UpdateImagePipeline"]
                                                       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}}/UpdateImagePipeline" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/UpdateImagePipeline",
  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([
    'imagePipelineArn' => '',
    'description' => '',
    'imageRecipeArn' => '',
    'containerRecipeArn' => '',
    'infrastructureConfigurationArn' => '',
    'distributionConfigurationArn' => '',
    'imageTestsConfiguration' => [
        'imageTestsEnabled' => '',
        'timeoutMinutes' => ''
    ],
    'enhancedImageMetadataEnabled' => null,
    'schedule' => [
        'scheduleExpression' => '',
        'timezone' => '',
        'pipelineExecutionStartCondition' => ''
    ],
    'status' => '',
    'clientToken' => '',
    'imageScanningConfiguration' => [
        'imageScanningEnabled' => '',
        'ecrConfiguration' => ''
    ]
  ]),
  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}}/UpdateImagePipeline', [
  'body' => '{
  "imagePipelineArn": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/UpdateImagePipeline');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'imagePipelineArn' => '',
  'description' => '',
  'imageRecipeArn' => '',
  'containerRecipeArn' => '',
  'infrastructureConfigurationArn' => '',
  'distributionConfigurationArn' => '',
  'imageTestsConfiguration' => [
    'imageTestsEnabled' => '',
    'timeoutMinutes' => ''
  ],
  'enhancedImageMetadataEnabled' => null,
  'schedule' => [
    'scheduleExpression' => '',
    'timezone' => '',
    'pipelineExecutionStartCondition' => ''
  ],
  'status' => '',
  'clientToken' => '',
  'imageScanningConfiguration' => [
    'imageScanningEnabled' => '',
    'ecrConfiguration' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'imagePipelineArn' => '',
  'description' => '',
  'imageRecipeArn' => '',
  'containerRecipeArn' => '',
  'infrastructureConfigurationArn' => '',
  'distributionConfigurationArn' => '',
  'imageTestsConfiguration' => [
    'imageTestsEnabled' => '',
    'timeoutMinutes' => ''
  ],
  'enhancedImageMetadataEnabled' => null,
  'schedule' => [
    'scheduleExpression' => '',
    'timezone' => '',
    'pipelineExecutionStartCondition' => ''
  ],
  'status' => '',
  'clientToken' => '',
  'imageScanningConfiguration' => [
    'imageScanningEnabled' => '',
    'ecrConfiguration' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/UpdateImagePipeline');
$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}}/UpdateImagePipeline' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "imagePipelineArn": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/UpdateImagePipeline' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "imagePipelineArn": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/UpdateImagePipeline", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/UpdateImagePipeline"

payload = {
    "imagePipelineArn": "",
    "description": "",
    "imageRecipeArn": "",
    "containerRecipeArn": "",
    "infrastructureConfigurationArn": "",
    "distributionConfigurationArn": "",
    "imageTestsConfiguration": {
        "imageTestsEnabled": "",
        "timeoutMinutes": ""
    },
    "enhancedImageMetadataEnabled": False,
    "schedule": {
        "scheduleExpression": "",
        "timezone": "",
        "pipelineExecutionStartCondition": ""
    },
    "status": "",
    "clientToken": "",
    "imageScanningConfiguration": {
        "imageScanningEnabled": "",
        "ecrConfiguration": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/UpdateImagePipeline"

payload <- "{\n  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/UpdateImagePipeline")

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  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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/UpdateImagePipeline') do |req|
  req.body = "{\n  \"imagePipelineArn\": \"\",\n  \"description\": \"\",\n  \"imageRecipeArn\": \"\",\n  \"containerRecipeArn\": \"\",\n  \"infrastructureConfigurationArn\": \"\",\n  \"distributionConfigurationArn\": \"\",\n  \"imageTestsConfiguration\": {\n    \"imageTestsEnabled\": \"\",\n    \"timeoutMinutes\": \"\"\n  },\n  \"enhancedImageMetadataEnabled\": false,\n  \"schedule\": {\n    \"scheduleExpression\": \"\",\n    \"timezone\": \"\",\n    \"pipelineExecutionStartCondition\": \"\"\n  },\n  \"status\": \"\",\n  \"clientToken\": \"\",\n  \"imageScanningConfiguration\": {\n    \"imageScanningEnabled\": \"\",\n    \"ecrConfiguration\": \"\"\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}}/UpdateImagePipeline";

    let payload = json!({
        "imagePipelineArn": "",
        "description": "",
        "imageRecipeArn": "",
        "containerRecipeArn": "",
        "infrastructureConfigurationArn": "",
        "distributionConfigurationArn": "",
        "imageTestsConfiguration": json!({
            "imageTestsEnabled": "",
            "timeoutMinutes": ""
        }),
        "enhancedImageMetadataEnabled": false,
        "schedule": json!({
            "scheduleExpression": "",
            "timezone": "",
            "pipelineExecutionStartCondition": ""
        }),
        "status": "",
        "clientToken": "",
        "imageScanningConfiguration": json!({
            "imageScanningEnabled": "",
            "ecrConfiguration": ""
        })
    });

    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}}/UpdateImagePipeline \
  --header 'content-type: application/json' \
  --data '{
  "imagePipelineArn": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}'
echo '{
  "imagePipelineArn": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": {
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  },
  "enhancedImageMetadataEnabled": false,
  "schedule": {
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  },
  "status": "",
  "clientToken": "",
  "imageScanningConfiguration": {
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  }
}' |  \
  http PUT {{baseUrl}}/UpdateImagePipeline \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "imagePipelineArn": "",\n  "description": "",\n  "imageRecipeArn": "",\n  "containerRecipeArn": "",\n  "infrastructureConfigurationArn": "",\n  "distributionConfigurationArn": "",\n  "imageTestsConfiguration": {\n    "imageTestsEnabled": "",\n    "timeoutMinutes": ""\n  },\n  "enhancedImageMetadataEnabled": false,\n  "schedule": {\n    "scheduleExpression": "",\n    "timezone": "",\n    "pipelineExecutionStartCondition": ""\n  },\n  "status": "",\n  "clientToken": "",\n  "imageScanningConfiguration": {\n    "imageScanningEnabled": "",\n    "ecrConfiguration": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/UpdateImagePipeline
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "imagePipelineArn": "",
  "description": "",
  "imageRecipeArn": "",
  "containerRecipeArn": "",
  "infrastructureConfigurationArn": "",
  "distributionConfigurationArn": "",
  "imageTestsConfiguration": [
    "imageTestsEnabled": "",
    "timeoutMinutes": ""
  ],
  "enhancedImageMetadataEnabled": false,
  "schedule": [
    "scheduleExpression": "",
    "timezone": "",
    "pipelineExecutionStartCondition": ""
  ],
  "status": "",
  "clientToken": "",
  "imageScanningConfiguration": [
    "imageScanningEnabled": "",
    "ecrConfiguration": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/UpdateImagePipeline")! 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 UpdateInfrastructureConfiguration
{{baseUrl}}/UpdateInfrastructureConfiguration
BODY json

{
  "infrastructureConfigurationArn": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "clientToken": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/UpdateInfrastructureConfiguration");

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  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/UpdateInfrastructureConfiguration" {:content-type :json
                                                                             :form-params {:infrastructureConfigurationArn ""
                                                                                           :description ""
                                                                                           :instanceTypes []
                                                                                           :instanceProfileName ""
                                                                                           :securityGroupIds []
                                                                                           :subnetId ""
                                                                                           :logging {:s3Logs ""}
                                                                                           :keyPair ""
                                                                                           :terminateInstanceOnFailure false
                                                                                           :snsTopicArn ""
                                                                                           :clientToken ""
                                                                                           :resourceTags {}
                                                                                           :instanceMetadataOptions {:httpTokens ""
                                                                                                                     :httpPutResponseHopLimit ""}}})
require "http/client"

url = "{{baseUrl}}/UpdateInfrastructureConfiguration"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\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}}/UpdateInfrastructureConfiguration"),
    Content = new StringContent("{\n  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\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}}/UpdateInfrastructureConfiguration");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/UpdateInfrastructureConfiguration"

	payload := strings.NewReader("{\n  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\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/UpdateInfrastructureConfiguration HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 408

{
  "infrastructureConfigurationArn": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "clientToken": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/UpdateInfrastructureConfiguration")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/UpdateInfrastructureConfiguration"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\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  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/UpdateInfrastructureConfiguration")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/UpdateInfrastructureConfiguration")
  .header("content-type", "application/json")
  .body("{\n  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  infrastructureConfigurationArn: '',
  description: '',
  instanceTypes: [],
  instanceProfileName: '',
  securityGroupIds: [],
  subnetId: '',
  logging: {
    s3Logs: ''
  },
  keyPair: '',
  terminateInstanceOnFailure: false,
  snsTopicArn: '',
  clientToken: '',
  resourceTags: {},
  instanceMetadataOptions: {
    httpTokens: '',
    httpPutResponseHopLimit: ''
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/UpdateInfrastructureConfiguration');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/UpdateInfrastructureConfiguration',
  headers: {'content-type': 'application/json'},
  data: {
    infrastructureConfigurationArn: '',
    description: '',
    instanceTypes: [],
    instanceProfileName: '',
    securityGroupIds: [],
    subnetId: '',
    logging: {s3Logs: ''},
    keyPair: '',
    terminateInstanceOnFailure: false,
    snsTopicArn: '',
    clientToken: '',
    resourceTags: {},
    instanceMetadataOptions: {httpTokens: '', httpPutResponseHopLimit: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/UpdateInfrastructureConfiguration';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"infrastructureConfigurationArn":"","description":"","instanceTypes":[],"instanceProfileName":"","securityGroupIds":[],"subnetId":"","logging":{"s3Logs":""},"keyPair":"","terminateInstanceOnFailure":false,"snsTopicArn":"","clientToken":"","resourceTags":{},"instanceMetadataOptions":{"httpTokens":"","httpPutResponseHopLimit":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/UpdateInfrastructureConfiguration',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "infrastructureConfigurationArn": "",\n  "description": "",\n  "instanceTypes": [],\n  "instanceProfileName": "",\n  "securityGroupIds": [],\n  "subnetId": "",\n  "logging": {\n    "s3Logs": ""\n  },\n  "keyPair": "",\n  "terminateInstanceOnFailure": false,\n  "snsTopicArn": "",\n  "clientToken": "",\n  "resourceTags": {},\n  "instanceMetadataOptions": {\n    "httpTokens": "",\n    "httpPutResponseHopLimit": ""\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  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/UpdateInfrastructureConfiguration")
  .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/UpdateInfrastructureConfiguration',
  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({
  infrastructureConfigurationArn: '',
  description: '',
  instanceTypes: [],
  instanceProfileName: '',
  securityGroupIds: [],
  subnetId: '',
  logging: {s3Logs: ''},
  keyPair: '',
  terminateInstanceOnFailure: false,
  snsTopicArn: '',
  clientToken: '',
  resourceTags: {},
  instanceMetadataOptions: {httpTokens: '', httpPutResponseHopLimit: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/UpdateInfrastructureConfiguration',
  headers: {'content-type': 'application/json'},
  body: {
    infrastructureConfigurationArn: '',
    description: '',
    instanceTypes: [],
    instanceProfileName: '',
    securityGroupIds: [],
    subnetId: '',
    logging: {s3Logs: ''},
    keyPair: '',
    terminateInstanceOnFailure: false,
    snsTopicArn: '',
    clientToken: '',
    resourceTags: {},
    instanceMetadataOptions: {httpTokens: '', httpPutResponseHopLimit: ''}
  },
  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}}/UpdateInfrastructureConfiguration');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  infrastructureConfigurationArn: '',
  description: '',
  instanceTypes: [],
  instanceProfileName: '',
  securityGroupIds: [],
  subnetId: '',
  logging: {
    s3Logs: ''
  },
  keyPair: '',
  terminateInstanceOnFailure: false,
  snsTopicArn: '',
  clientToken: '',
  resourceTags: {},
  instanceMetadataOptions: {
    httpTokens: '',
    httpPutResponseHopLimit: ''
  }
});

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}}/UpdateInfrastructureConfiguration',
  headers: {'content-type': 'application/json'},
  data: {
    infrastructureConfigurationArn: '',
    description: '',
    instanceTypes: [],
    instanceProfileName: '',
    securityGroupIds: [],
    subnetId: '',
    logging: {s3Logs: ''},
    keyPair: '',
    terminateInstanceOnFailure: false,
    snsTopicArn: '',
    clientToken: '',
    resourceTags: {},
    instanceMetadataOptions: {httpTokens: '', httpPutResponseHopLimit: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/UpdateInfrastructureConfiguration';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"infrastructureConfigurationArn":"","description":"","instanceTypes":[],"instanceProfileName":"","securityGroupIds":[],"subnetId":"","logging":{"s3Logs":""},"keyPair":"","terminateInstanceOnFailure":false,"snsTopicArn":"","clientToken":"","resourceTags":{},"instanceMetadataOptions":{"httpTokens":"","httpPutResponseHopLimit":""}}'
};

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 = @{ @"infrastructureConfigurationArn": @"",
                              @"description": @"",
                              @"instanceTypes": @[  ],
                              @"instanceProfileName": @"",
                              @"securityGroupIds": @[  ],
                              @"subnetId": @"",
                              @"logging": @{ @"s3Logs": @"" },
                              @"keyPair": @"",
                              @"terminateInstanceOnFailure": @NO,
                              @"snsTopicArn": @"",
                              @"clientToken": @"",
                              @"resourceTags": @{  },
                              @"instanceMetadataOptions": @{ @"httpTokens": @"", @"httpPutResponseHopLimit": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/UpdateInfrastructureConfiguration"]
                                                       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}}/UpdateInfrastructureConfiguration" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/UpdateInfrastructureConfiguration",
  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([
    'infrastructureConfigurationArn' => '',
    'description' => '',
    'instanceTypes' => [
        
    ],
    'instanceProfileName' => '',
    'securityGroupIds' => [
        
    ],
    'subnetId' => '',
    'logging' => [
        's3Logs' => ''
    ],
    'keyPair' => '',
    'terminateInstanceOnFailure' => null,
    'snsTopicArn' => '',
    'clientToken' => '',
    'resourceTags' => [
        
    ],
    'instanceMetadataOptions' => [
        'httpTokens' => '',
        'httpPutResponseHopLimit' => ''
    ]
  ]),
  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}}/UpdateInfrastructureConfiguration', [
  'body' => '{
  "infrastructureConfigurationArn": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "clientToken": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/UpdateInfrastructureConfiguration');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'infrastructureConfigurationArn' => '',
  'description' => '',
  'instanceTypes' => [
    
  ],
  'instanceProfileName' => '',
  'securityGroupIds' => [
    
  ],
  'subnetId' => '',
  'logging' => [
    's3Logs' => ''
  ],
  'keyPair' => '',
  'terminateInstanceOnFailure' => null,
  'snsTopicArn' => '',
  'clientToken' => '',
  'resourceTags' => [
    
  ],
  'instanceMetadataOptions' => [
    'httpTokens' => '',
    'httpPutResponseHopLimit' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'infrastructureConfigurationArn' => '',
  'description' => '',
  'instanceTypes' => [
    
  ],
  'instanceProfileName' => '',
  'securityGroupIds' => [
    
  ],
  'subnetId' => '',
  'logging' => [
    's3Logs' => ''
  ],
  'keyPair' => '',
  'terminateInstanceOnFailure' => null,
  'snsTopicArn' => '',
  'clientToken' => '',
  'resourceTags' => [
    
  ],
  'instanceMetadataOptions' => [
    'httpTokens' => '',
    'httpPutResponseHopLimit' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/UpdateInfrastructureConfiguration');
$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}}/UpdateInfrastructureConfiguration' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "infrastructureConfigurationArn": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "clientToken": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/UpdateInfrastructureConfiguration' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "infrastructureConfigurationArn": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "clientToken": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/UpdateInfrastructureConfiguration", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/UpdateInfrastructureConfiguration"

payload = {
    "infrastructureConfigurationArn": "",
    "description": "",
    "instanceTypes": [],
    "instanceProfileName": "",
    "securityGroupIds": [],
    "subnetId": "",
    "logging": { "s3Logs": "" },
    "keyPair": "",
    "terminateInstanceOnFailure": False,
    "snsTopicArn": "",
    "clientToken": "",
    "resourceTags": {},
    "instanceMetadataOptions": {
        "httpTokens": "",
        "httpPutResponseHopLimit": ""
    }
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/UpdateInfrastructureConfiguration"

payload <- "{\n  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\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}}/UpdateInfrastructureConfiguration")

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  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\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/UpdateInfrastructureConfiguration') do |req|
  req.body = "{\n  \"infrastructureConfigurationArn\": \"\",\n  \"description\": \"\",\n  \"instanceTypes\": [],\n  \"instanceProfileName\": \"\",\n  \"securityGroupIds\": [],\n  \"subnetId\": \"\",\n  \"logging\": {\n    \"s3Logs\": \"\"\n  },\n  \"keyPair\": \"\",\n  \"terminateInstanceOnFailure\": false,\n  \"snsTopicArn\": \"\",\n  \"clientToken\": \"\",\n  \"resourceTags\": {},\n  \"instanceMetadataOptions\": {\n    \"httpTokens\": \"\",\n    \"httpPutResponseHopLimit\": \"\"\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}}/UpdateInfrastructureConfiguration";

    let payload = json!({
        "infrastructureConfigurationArn": "",
        "description": "",
        "instanceTypes": (),
        "instanceProfileName": "",
        "securityGroupIds": (),
        "subnetId": "",
        "logging": json!({"s3Logs": ""}),
        "keyPair": "",
        "terminateInstanceOnFailure": false,
        "snsTopicArn": "",
        "clientToken": "",
        "resourceTags": json!({}),
        "instanceMetadataOptions": json!({
            "httpTokens": "",
            "httpPutResponseHopLimit": ""
        })
    });

    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}}/UpdateInfrastructureConfiguration \
  --header 'content-type: application/json' \
  --data '{
  "infrastructureConfigurationArn": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "clientToken": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  }
}'
echo '{
  "infrastructureConfigurationArn": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": {
    "s3Logs": ""
  },
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "clientToken": "",
  "resourceTags": {},
  "instanceMetadataOptions": {
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  }
}' |  \
  http PUT {{baseUrl}}/UpdateInfrastructureConfiguration \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "infrastructureConfigurationArn": "",\n  "description": "",\n  "instanceTypes": [],\n  "instanceProfileName": "",\n  "securityGroupIds": [],\n  "subnetId": "",\n  "logging": {\n    "s3Logs": ""\n  },\n  "keyPair": "",\n  "terminateInstanceOnFailure": false,\n  "snsTopicArn": "",\n  "clientToken": "",\n  "resourceTags": {},\n  "instanceMetadataOptions": {\n    "httpTokens": "",\n    "httpPutResponseHopLimit": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/UpdateInfrastructureConfiguration
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "infrastructureConfigurationArn": "",
  "description": "",
  "instanceTypes": [],
  "instanceProfileName": "",
  "securityGroupIds": [],
  "subnetId": "",
  "logging": ["s3Logs": ""],
  "keyPair": "",
  "terminateInstanceOnFailure": false,
  "snsTopicArn": "",
  "clientToken": "",
  "resourceTags": [],
  "instanceMetadataOptions": [
    "httpTokens": "",
    "httpPutResponseHopLimit": ""
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/UpdateInfrastructureConfiguration")! 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()