POST adexchangebuyer2.accounts.clients.create
{{baseUrl}}/v2beta1/accounts/:accountId/clients
QUERY PARAMS

accountId
BODY json

{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/clients");

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  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}");

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

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/clients" {:content-type :json
                                                                                :form-params {:clientAccountId ""
                                                                                              :clientName ""
                                                                                              :entityId ""
                                                                                              :entityName ""
                                                                                              :entityType ""
                                                                                              :partnerClientId ""
                                                                                              :role ""
                                                                                              :status ""
                                                                                              :visibleToSeller false}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": 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}}/v2beta1/accounts/:accountId/clients"),
    Content = new StringContent("{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": 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}}/v2beta1/accounts/:accountId/clients");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/clients"

	payload := strings.NewReader("{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": 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/v2beta1/accounts/:accountId/clients HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 188

{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/clients")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/clients"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": 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  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/clients")
  .header("content-type", "application/json")
  .body("{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}")
  .asString();
const data = JSON.stringify({
  clientAccountId: '',
  clientName: '',
  entityId: '',
  entityName: '',
  entityType: '',
  partnerClientId: '',
  role: '',
  status: '',
  visibleToSeller: 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}}/v2beta1/accounts/:accountId/clients');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients',
  headers: {'content-type': 'application/json'},
  data: {
    clientAccountId: '',
    clientName: '',
    entityId: '',
    entityName: '',
    entityType: '',
    partnerClientId: '',
    role: '',
    status: '',
    visibleToSeller: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clientAccountId":"","clientName":"","entityId":"","entityName":"","entityType":"","partnerClientId":"","role":"","status":"","visibleToSeller":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}}/v2beta1/accounts/:accountId/clients',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clientAccountId": "",\n  "clientName": "",\n  "entityId": "",\n  "entityName": "",\n  "entityType": "",\n  "partnerClientId": "",\n  "role": "",\n  "status": "",\n  "visibleToSeller": 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  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients")
  .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/v2beta1/accounts/:accountId/clients',
  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({
  clientAccountId: '',
  clientName: '',
  entityId: '',
  entityName: '',
  entityType: '',
  partnerClientId: '',
  role: '',
  status: '',
  visibleToSeller: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients',
  headers: {'content-type': 'application/json'},
  body: {
    clientAccountId: '',
    clientName: '',
    entityId: '',
    entityName: '',
    entityType: '',
    partnerClientId: '',
    role: '',
    status: '',
    visibleToSeller: 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}}/v2beta1/accounts/:accountId/clients');

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

req.type('json');
req.send({
  clientAccountId: '',
  clientName: '',
  entityId: '',
  entityName: '',
  entityType: '',
  partnerClientId: '',
  role: '',
  status: '',
  visibleToSeller: 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}}/v2beta1/accounts/:accountId/clients',
  headers: {'content-type': 'application/json'},
  data: {
    clientAccountId: '',
    clientName: '',
    entityId: '',
    entityName: '',
    entityType: '',
    partnerClientId: '',
    role: '',
    status: '',
    visibleToSeller: false
  }
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clientAccountId":"","clientName":"","entityId":"","entityName":"","entityType":"","partnerClientId":"","role":"","status":"","visibleToSeller":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 = @{ @"clientAccountId": @"",
                              @"clientName": @"",
                              @"entityId": @"",
                              @"entityName": @"",
                              @"entityType": @"",
                              @"partnerClientId": @"",
                              @"role": @"",
                              @"status": @"",
                              @"visibleToSeller": @NO };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/clients" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/clients",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'clientAccountId' => '',
    'clientName' => '',
    'entityId' => '',
    'entityName' => '',
    'entityType' => '',
    'partnerClientId' => '',
    'role' => '',
    'status' => '',
    'visibleToSeller' => 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}}/v2beta1/accounts/:accountId/clients', [
  'body' => '{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clientAccountId' => '',
  'clientName' => '',
  'entityId' => '',
  'entityName' => '',
  'entityType' => '',
  'partnerClientId' => '',
  'role' => '',
  'status' => '',
  'visibleToSeller' => null
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clientAccountId' => '',
  'clientName' => '',
  'entityId' => '',
  'entityName' => '',
  'entityType' => '',
  'partnerClientId' => '',
  'role' => '',
  'status' => '',
  'visibleToSeller' => null
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients');
$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}}/v2beta1/accounts/:accountId/clients' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}'
import http.client

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

payload = "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}"

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

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/clients", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients"

payload = {
    "clientAccountId": "",
    "clientName": "",
    "entityId": "",
    "entityName": "",
    "entityType": "",
    "partnerClientId": "",
    "role": "",
    "status": "",
    "visibleToSeller": False
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/clients"

payload <- "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": 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}}/v2beta1/accounts/:accountId/clients")

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  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": 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/v2beta1/accounts/:accountId/clients') do |req|
  req.body = "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}"
end

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

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

    let payload = json!({
        "clientAccountId": "",
        "clientName": "",
        "entityId": "",
        "entityName": "",
        "entityType": "",
        "partnerClientId": "",
        "role": "",
        "status": "",
        "visibleToSeller": 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}}/v2beta1/accounts/:accountId/clients \
  --header 'content-type: application/json' \
  --data '{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}'
echo '{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/clients \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clientAccountId": "",\n  "clientName": "",\n  "entityId": "",\n  "entityName": "",\n  "entityType": "",\n  "partnerClientId": "",\n  "role": "",\n  "status": "",\n  "visibleToSeller": false\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/clients
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
] as [String : Any]

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

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

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

dataTask.resume()
GET adexchangebuyer2.accounts.clients.get
{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId
QUERY PARAMS

accountId
clientAccountId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId"

	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/v2beta1/accounts/:accountId/clients/:clientAccountId HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId';
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}}/v2beta1/accounts/:accountId/clients/:clientAccountId"]
                                                       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}}/v2beta1/accounts/:accountId/clients/:clientAccountId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")

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/v2beta1/accounts/:accountId/clients/:clientAccountId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId";

    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}}/v2beta1/accounts/:accountId/clients/:clientAccountId
http GET {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")! 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 adexchangebuyer2.accounts.clients.invitations.create
{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations
QUERY PARAMS

accountId
clientAccountId
BODY json

{
  "clientAccountId": "",
  "email": "",
  "invitationId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations");

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  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}");

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

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations" {:content-type :json
                                                                                                             :form-params {:clientAccountId ""
                                                                                                                           :email ""
                                                                                                                           :invitationId ""}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"),
    Content = new StringContent("{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"

	payload := strings.NewReader("{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\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/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 64

{
  "clientAccountId": "",
  "email": "",
  "invitationId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")
  .header("content-type", "application/json")
  .body("{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clientAccountId: '',
  email: '',
  invitationId: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations',
  headers: {'content-type': 'application/json'},
  data: {clientAccountId: '', email: '', invitationId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clientAccountId":"","email":"","invitationId":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clientAccountId": "",\n  "email": "",\n  "invitationId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")
  .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/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations',
  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({clientAccountId: '', email: '', invitationId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations',
  headers: {'content-type': 'application/json'},
  body: {clientAccountId: '', email: '', invitationId: ''},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations');

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

req.type('json');
req.send({
  clientAccountId: '',
  email: '',
  invitationId: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations',
  headers: {'content-type': 'application/json'},
  data: {clientAccountId: '', email: '', invitationId: ''}
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clientAccountId":"","email":"","invitationId":""}'
};

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 = @{ @"clientAccountId": @"",
                              @"email": @"",
                              @"invitationId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'clientAccountId' => '',
    'email' => '',
    'invitationId' => ''
  ]),
  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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations', [
  'body' => '{
  "clientAccountId": "",
  "email": "",
  "invitationId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clientAccountId' => '',
  'email' => '',
  'invitationId' => ''
]));

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

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

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

payload = "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"

payload = {
    "clientAccountId": "",
    "email": "",
    "invitationId": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"

payload <- "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")

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  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}"

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

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

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations') do |req|
  req.body = "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"invitationId\": \"\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations";

    let payload = json!({
        "clientAccountId": "",
        "email": "",
        "invitationId": ""
    });

    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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations \
  --header 'content-type: application/json' \
  --data '{
  "clientAccountId": "",
  "email": "",
  "invitationId": ""
}'
echo '{
  "clientAccountId": "",
  "email": "",
  "invitationId": ""
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clientAccountId": "",\n  "email": "",\n  "invitationId": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clientAccountId": "",
  "email": "",
  "invitationId": ""
] as [String : Any]

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

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

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

dataTask.resume()
GET adexchangebuyer2.accounts.clients.invitations.get
{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId
QUERY PARAMS

accountId
clientAccountId
invitationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId"

	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/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId';
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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId"]
                                                       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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId",
  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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId")

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/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId";

    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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId
http GET {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations/:invitationId")! 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 adexchangebuyer2.accounts.clients.invitations.list
{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations
QUERY PARAMS

accountId
clientAccountId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"

	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/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations';
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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"]
                                                       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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")

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/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations";

    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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations
http GET {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/invitations")! 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 adexchangebuyer2.accounts.clients.list
{{baseUrl}}/v2beta1/accounts/:accountId/clients
QUERY PARAMS

accountId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/clients");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/clients")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/clients"

	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/v2beta1/accounts/:accountId/clients HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/clients")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/clients',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients';
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}}/v2beta1/accounts/:accountId/clients"]
                                                       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}}/v2beta1/accounts/:accountId/clients" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/clients")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/clients"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/clients")

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/v2beta1/accounts/:accountId/clients') do |req|
end

puts response.status
puts response.body
use reqwest;

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

    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}}/v2beta1/accounts/:accountId/clients
http GET {{baseUrl}}/v2beta1/accounts/:accountId/clients
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/clients
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/clients")! 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 adexchangebuyer2.accounts.clients.update
{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId
QUERY PARAMS

accountId
clientAccountId
BODY json

{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId");

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  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}");

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

(client/put "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId" {:content-type :json
                                                                                                :form-params {:clientAccountId ""
                                                                                                              :clientName ""
                                                                                                              :entityId ""
                                                                                                              :entityName ""
                                                                                                              :entityType ""
                                                                                                              :partnerClientId ""
                                                                                                              :role ""
                                                                                                              :status ""
                                                                                                              :visibleToSeller false}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId"),
    Content = new StringContent("{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": 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}}/v2beta1/accounts/:accountId/clients/:clientAccountId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId"

	payload := strings.NewReader("{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}")

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

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

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

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

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

}
PUT /baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 188

{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": 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  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")
  .header("content-type", "application/json")
  .body("{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}")
  .asString();
const data = JSON.stringify({
  clientAccountId: '',
  clientName: '',
  entityId: '',
  entityName: '',
  entityType: '',
  partnerClientId: '',
  role: '',
  status: '',
  visibleToSeller: false
});

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

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

xhr.open('PUT', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId',
  headers: {'content-type': 'application/json'},
  data: {
    clientAccountId: '',
    clientName: '',
    entityId: '',
    entityName: '',
    entityType: '',
    partnerClientId: '',
    role: '',
    status: '',
    visibleToSeller: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"clientAccountId":"","clientName":"","entityId":"","entityName":"","entityType":"","partnerClientId":"","role":"","status":"","visibleToSeller":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}}/v2beta1/accounts/:accountId/clients/:clientAccountId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clientAccountId": "",\n  "clientName": "",\n  "entityId": "",\n  "entityName": "",\n  "entityType": "",\n  "partnerClientId": "",\n  "role": "",\n  "status": "",\n  "visibleToSeller": 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  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")
  .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/v2beta1/accounts/:accountId/clients/:clientAccountId',
  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({
  clientAccountId: '',
  clientName: '',
  entityId: '',
  entityName: '',
  entityType: '',
  partnerClientId: '',
  role: '',
  status: '',
  visibleToSeller: false
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId',
  headers: {'content-type': 'application/json'},
  body: {
    clientAccountId: '',
    clientName: '',
    entityId: '',
    entityName: '',
    entityType: '',
    partnerClientId: '',
    role: '',
    status: '',
    visibleToSeller: false
  },
  json: true
};

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

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

const req = unirest('PUT', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId');

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

req.type('json');
req.send({
  clientAccountId: '',
  clientName: '',
  entityId: '',
  entityName: '',
  entityType: '',
  partnerClientId: '',
  role: '',
  status: '',
  visibleToSeller: false
});

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId',
  headers: {'content-type': 'application/json'},
  data: {
    clientAccountId: '',
    clientName: '',
    entityId: '',
    entityName: '',
    entityType: '',
    partnerClientId: '',
    role: '',
    status: '',
    visibleToSeller: false
  }
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"clientAccountId":"","clientName":"","entityId":"","entityName":"","entityType":"","partnerClientId":"","role":"","status":"","visibleToSeller":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 = @{ @"clientAccountId": @"",
                              @"clientName": @"",
                              @"entityId": @"",
                              @"entityName": @"",
                              @"entityType": @"",
                              @"partnerClientId": @"",
                              @"role": @"",
                              @"status": @"",
                              @"visibleToSeller": @NO };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId"]
                                                       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}}/v2beta1/accounts/:accountId/clients/:clientAccountId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId",
  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([
    'clientAccountId' => '',
    'clientName' => '',
    'entityId' => '',
    'entityName' => '',
    'entityType' => '',
    'partnerClientId' => '',
    'role' => '',
    'status' => '',
    'visibleToSeller' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId', [
  'body' => '{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId');
$request->setMethod(HTTP_METH_PUT);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clientAccountId' => '',
  'clientName' => '',
  'entityId' => '',
  'entityName' => '',
  'entityType' => '',
  'partnerClientId' => '',
  'role' => '',
  'status' => '',
  'visibleToSeller' => null
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clientAccountId' => '',
  'clientName' => '',
  'entityId' => '',
  'entityName' => '',
  'entityType' => '',
  'partnerClientId' => '',
  'role' => '',
  'status' => '',
  'visibleToSeller' => null
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId');
$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}}/v2beta1/accounts/:accountId/clients/:clientAccountId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}'
import http.client

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

payload = "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}"

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

conn.request("PUT", "/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId"

payload = {
    "clientAccountId": "",
    "clientName": "",
    "entityId": "",
    "entityName": "",
    "entityType": "",
    "partnerClientId": "",
    "role": "",
    "status": "",
    "visibleToSeller": False
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId"

payload <- "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")

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  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}"

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

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

response = conn.put('/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId') do |req|
  req.body = "{\n  \"clientAccountId\": \"\",\n  \"clientName\": \"\",\n  \"entityId\": \"\",\n  \"entityName\": \"\",\n  \"entityType\": \"\",\n  \"partnerClientId\": \"\",\n  \"role\": \"\",\n  \"status\": \"\",\n  \"visibleToSeller\": false\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId";

    let payload = json!({
        "clientAccountId": "",
        "clientName": "",
        "entityId": "",
        "entityName": "",
        "entityType": "",
        "partnerClientId": "",
        "role": "",
        "status": "",
        "visibleToSeller": false
    });

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId \
  --header 'content-type: application/json' \
  --data '{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}'
echo '{
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
}' |  \
  http PUT {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "clientAccountId": "",\n  "clientName": "",\n  "entityId": "",\n  "entityName": "",\n  "entityType": "",\n  "partnerClientId": "",\n  "role": "",\n  "status": "",\n  "visibleToSeller": false\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clientAccountId": "",
  "clientName": "",
  "entityId": "",
  "entityName": "",
  "entityType": "",
  "partnerClientId": "",
  "role": "",
  "status": "",
  "visibleToSeller": false
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
GET adexchangebuyer2.accounts.clients.users.get
{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId
QUERY PARAMS

accountId
clientAccountId
userId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId"

	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/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId';
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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId"]
                                                       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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId",
  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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")

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/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId";

    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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId
http GET {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")! 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 adexchangebuyer2.accounts.clients.users.list
{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users
QUERY PARAMS

accountId
clientAccountId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users"

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

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

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

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

}
GET /baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/users HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users',
  method: 'GET',
  headers: {}
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/users',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/users")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users")

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

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

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

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

response = conn.get('/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/users') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users";

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users
http GET {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

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

dataTask.resume()
PUT adexchangebuyer2.accounts.clients.users.update
{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId
QUERY PARAMS

accountId
clientAccountId
userId
BODY json

{
  "clientAccountId": "",
  "email": "",
  "status": "",
  "userId": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId");

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  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\n}");

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

(client/put "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId" {:content-type :json
                                                                                                              :form-params {:clientAccountId ""
                                                                                                                            :email ""
                                                                                                                            :status ""
                                                                                                                            :userId ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId"

	payload := strings.NewReader("{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\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/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 74

{
  "clientAccountId": "",
  "email": "",
  "status": "",
  "userId": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")
  .header("content-type", "application/json")
  .body("{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clientAccountId: '',
  email: '',
  status: '',
  userId: ''
});

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

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

xhr.open('PUT', '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId',
  headers: {'content-type': 'application/json'},
  data: {clientAccountId: '', email: '', status: '', userId: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"clientAccountId":"","email":"","status":"","userId":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clientAccountId": "",\n  "email": "",\n  "status": "",\n  "userId": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")
  .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/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId',
  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({clientAccountId: '', email: '', status: '', userId: ''}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId',
  headers: {'content-type': 'application/json'},
  body: {clientAccountId: '', email: '', status: '', userId: ''},
  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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId');

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

req.type('json');
req.send({
  clientAccountId: '',
  email: '',
  status: '',
  userId: ''
});

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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId',
  headers: {'content-type': 'application/json'},
  data: {clientAccountId: '', email: '', status: '', userId: ''}
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"clientAccountId":"","email":"","status":"","userId":""}'
};

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 = @{ @"clientAccountId": @"",
                              @"email": @"",
                              @"status": @"",
                              @"userId": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId"]
                                                       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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId",
  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([
    'clientAccountId' => '',
    'email' => '',
    'status' => '',
    'userId' => ''
  ]),
  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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId', [
  'body' => '{
  "clientAccountId": "",
  "email": "",
  "status": "",
  "userId": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId');
$request->setMethod(HTTP_METH_PUT);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clientAccountId' => '',
  'email' => '',
  'status' => '',
  'userId' => ''
]));

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

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

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

payload = "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\n}"

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

conn.request("PUT", "/baseUrl/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId"

payload = {
    "clientAccountId": "",
    "email": "",
    "status": "",
    "userId": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId"

payload <- "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")

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  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\n}"

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/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId') do |req|
  req.body = "{\n  \"clientAccountId\": \"\",\n  \"email\": \"\",\n  \"status\": \"\",\n  \"userId\": \"\"\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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId";

    let payload = json!({
        "clientAccountId": "",
        "email": "",
        "status": "",
        "userId": ""
    });

    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}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId \
  --header 'content-type: application/json' \
  --data '{
  "clientAccountId": "",
  "email": "",
  "status": "",
  "userId": ""
}'
echo '{
  "clientAccountId": "",
  "email": "",
  "status": "",
  "userId": ""
}' |  \
  http PUT {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "clientAccountId": "",\n  "email": "",\n  "status": "",\n  "userId": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clientAccountId": "",
  "email": "",
  "status": "",
  "userId": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/clients/:clientAccountId/users/:userId")! 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 adexchangebuyer2.accounts.creatives.create
{{baseUrl}}/v2beta1/accounts/:accountId/creatives
QUERY PARAMS

accountId
BODY json

{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/creatives");

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  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}");

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

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/creatives" {:content-type :json
                                                                                  :form-params {:accountId ""
                                                                                                :adChoicesDestinationUrl ""
                                                                                                :adTechnologyProviders {:detectedProviderIds []
                                                                                                                        :hasUnidentifiedProvider false}
                                                                                                :advertiserName ""
                                                                                                :agencyId ""
                                                                                                :apiUpdateTime ""
                                                                                                :attributes []
                                                                                                :clickThroughUrls []
                                                                                                :corrections [{:contexts [{:all ""
                                                                                                                           :appType {:appTypes []}
                                                                                                                           :auctionType {:auctionTypes []}
                                                                                                                           :location {:geoCriteriaIds []}
                                                                                                                           :platform {:platforms []}
                                                                                                                           :securityType {:securities []}}]
                                                                                                               :details []
                                                                                                               :type ""}]
                                                                                                :creativeId ""
                                                                                                :dealsStatus ""
                                                                                                :declaredClickThroughUrls []
                                                                                                :detectedAdvertiserIds []
                                                                                                :detectedDomains []
                                                                                                :detectedLanguages []
                                                                                                :detectedProductCategories []
                                                                                                :detectedSensitiveCategories []
                                                                                                :html {:height 0
                                                                                                       :snippet ""
                                                                                                       :width 0}
                                                                                                :impressionTrackingUrls []
                                                                                                :native {:advertiserName ""
                                                                                                         :appIcon {:height 0
                                                                                                                   :url ""
                                                                                                                   :width 0}
                                                                                                         :body ""
                                                                                                         :callToAction ""
                                                                                                         :clickLinkUrl ""
                                                                                                         :clickTrackingUrl ""
                                                                                                         :headline ""
                                                                                                         :image {}
                                                                                                         :logo {}
                                                                                                         :priceDisplayText ""
                                                                                                         :starRating ""
                                                                                                         :storeUrl ""
                                                                                                         :videoUrl ""}
                                                                                                :openAuctionStatus ""
                                                                                                :restrictedCategories []
                                                                                                :servingRestrictions [{:contexts [{}]
                                                                                                                       :disapproval {:details []
                                                                                                                                     :reason ""}
                                                                                                                       :disapprovalReasons [{}]
                                                                                                                       :status ""}]
                                                                                                :vendorIds []
                                                                                                :version 0
                                                                                                :video {:videoUrl ""
                                                                                                        :videoVastXml ""}}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/creatives"),
    Content = new StringContent("{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\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}}/v2beta1/accounts/:accountId/creatives");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/creatives"

	payload := strings.NewReader("{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v2beta1/accounts/:accountId/creatives HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1817

{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/creatives")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/creatives"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\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  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/creatives")
  .header("content-type", "application/json")
  .body("{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  accountId: '',
  adChoicesDestinationUrl: '',
  adTechnologyProviders: {
    detectedProviderIds: [],
    hasUnidentifiedProvider: false
  },
  advertiserName: '',
  agencyId: '',
  apiUpdateTime: '',
  attributes: [],
  clickThroughUrls: [],
  corrections: [
    {
      contexts: [
        {
          all: '',
          appType: {
            appTypes: []
          },
          auctionType: {
            auctionTypes: []
          },
          location: {
            geoCriteriaIds: []
          },
          platform: {
            platforms: []
          },
          securityType: {
            securities: []
          }
        }
      ],
      details: [],
      type: ''
    }
  ],
  creativeId: '',
  dealsStatus: '',
  declaredClickThroughUrls: [],
  detectedAdvertiserIds: [],
  detectedDomains: [],
  detectedLanguages: [],
  detectedProductCategories: [],
  detectedSensitiveCategories: [],
  html: {
    height: 0,
    snippet: '',
    width: 0
  },
  impressionTrackingUrls: [],
  native: {
    advertiserName: '',
    appIcon: {
      height: 0,
      url: '',
      width: 0
    },
    body: '',
    callToAction: '',
    clickLinkUrl: '',
    clickTrackingUrl: '',
    headline: '',
    image: {},
    logo: {},
    priceDisplayText: '',
    starRating: '',
    storeUrl: '',
    videoUrl: ''
  },
  openAuctionStatus: '',
  restrictedCategories: [],
  servingRestrictions: [
    {
      contexts: [
        {}
      ],
      disapproval: {
        details: [],
        reason: ''
      },
      disapprovalReasons: [
        {}
      ],
      status: ''
    }
  ],
  vendorIds: [],
  version: 0,
  video: {
    videoUrl: '',
    videoVastXml: ''
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives',
  headers: {'content-type': 'application/json'},
  data: {
    accountId: '',
    adChoicesDestinationUrl: '',
    adTechnologyProviders: {detectedProviderIds: [], hasUnidentifiedProvider: false},
    advertiserName: '',
    agencyId: '',
    apiUpdateTime: '',
    attributes: [],
    clickThroughUrls: [],
    corrections: [
      {
        contexts: [
          {
            all: '',
            appType: {appTypes: []},
            auctionType: {auctionTypes: []},
            location: {geoCriteriaIds: []},
            platform: {platforms: []},
            securityType: {securities: []}
          }
        ],
        details: [],
        type: ''
      }
    ],
    creativeId: '',
    dealsStatus: '',
    declaredClickThroughUrls: [],
    detectedAdvertiserIds: [],
    detectedDomains: [],
    detectedLanguages: [],
    detectedProductCategories: [],
    detectedSensitiveCategories: [],
    html: {height: 0, snippet: '', width: 0},
    impressionTrackingUrls: [],
    native: {
      advertiserName: '',
      appIcon: {height: 0, url: '', width: 0},
      body: '',
      callToAction: '',
      clickLinkUrl: '',
      clickTrackingUrl: '',
      headline: '',
      image: {},
      logo: {},
      priceDisplayText: '',
      starRating: '',
      storeUrl: '',
      videoUrl: ''
    },
    openAuctionStatus: '',
    restrictedCategories: [],
    servingRestrictions: [
      {
        contexts: [{}],
        disapproval: {details: [], reason: ''},
        disapprovalReasons: [{}],
        status: ''
      }
    ],
    vendorIds: [],
    version: 0,
    video: {videoUrl: '', videoVastXml: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"accountId":"","adChoicesDestinationUrl":"","adTechnologyProviders":{"detectedProviderIds":[],"hasUnidentifiedProvider":false},"advertiserName":"","agencyId":"","apiUpdateTime":"","attributes":[],"clickThroughUrls":[],"corrections":[{"contexts":[{"all":"","appType":{"appTypes":[]},"auctionType":{"auctionTypes":[]},"location":{"geoCriteriaIds":[]},"platform":{"platforms":[]},"securityType":{"securities":[]}}],"details":[],"type":""}],"creativeId":"","dealsStatus":"","declaredClickThroughUrls":[],"detectedAdvertiserIds":[],"detectedDomains":[],"detectedLanguages":[],"detectedProductCategories":[],"detectedSensitiveCategories":[],"html":{"height":0,"snippet":"","width":0},"impressionTrackingUrls":[],"native":{"advertiserName":"","appIcon":{"height":0,"url":"","width":0},"body":"","callToAction":"","clickLinkUrl":"","clickTrackingUrl":"","headline":"","image":{},"logo":{},"priceDisplayText":"","starRating":"","storeUrl":"","videoUrl":""},"openAuctionStatus":"","restrictedCategories":[],"servingRestrictions":[{"contexts":[{}],"disapproval":{"details":[],"reason":""},"disapprovalReasons":[{}],"status":""}],"vendorIds":[],"version":0,"video":{"videoUrl":"","videoVastXml":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "accountId": "",\n  "adChoicesDestinationUrl": "",\n  "adTechnologyProviders": {\n    "detectedProviderIds": [],\n    "hasUnidentifiedProvider": false\n  },\n  "advertiserName": "",\n  "agencyId": "",\n  "apiUpdateTime": "",\n  "attributes": [],\n  "clickThroughUrls": [],\n  "corrections": [\n    {\n      "contexts": [\n        {\n          "all": "",\n          "appType": {\n            "appTypes": []\n          },\n          "auctionType": {\n            "auctionTypes": []\n          },\n          "location": {\n            "geoCriteriaIds": []\n          },\n          "platform": {\n            "platforms": []\n          },\n          "securityType": {\n            "securities": []\n          }\n        }\n      ],\n      "details": [],\n      "type": ""\n    }\n  ],\n  "creativeId": "",\n  "dealsStatus": "",\n  "declaredClickThroughUrls": [],\n  "detectedAdvertiserIds": [],\n  "detectedDomains": [],\n  "detectedLanguages": [],\n  "detectedProductCategories": [],\n  "detectedSensitiveCategories": [],\n  "html": {\n    "height": 0,\n    "snippet": "",\n    "width": 0\n  },\n  "impressionTrackingUrls": [],\n  "native": {\n    "advertiserName": "",\n    "appIcon": {\n      "height": 0,\n      "url": "",\n      "width": 0\n    },\n    "body": "",\n    "callToAction": "",\n    "clickLinkUrl": "",\n    "clickTrackingUrl": "",\n    "headline": "",\n    "image": {},\n    "logo": {},\n    "priceDisplayText": "",\n    "starRating": "",\n    "storeUrl": "",\n    "videoUrl": ""\n  },\n  "openAuctionStatus": "",\n  "restrictedCategories": [],\n  "servingRestrictions": [\n    {\n      "contexts": [\n        {}\n      ],\n      "disapproval": {\n        "details": [],\n        "reason": ""\n      },\n      "disapprovalReasons": [\n        {}\n      ],\n      "status": ""\n    }\n  ],\n  "vendorIds": [],\n  "version": 0,\n  "video": {\n    "videoUrl": "",\n    "videoVastXml": ""\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  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives")
  .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/v2beta1/accounts/:accountId/creatives',
  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({
  accountId: '',
  adChoicesDestinationUrl: '',
  adTechnologyProviders: {detectedProviderIds: [], hasUnidentifiedProvider: false},
  advertiserName: '',
  agencyId: '',
  apiUpdateTime: '',
  attributes: [],
  clickThroughUrls: [],
  corrections: [
    {
      contexts: [
        {
          all: '',
          appType: {appTypes: []},
          auctionType: {auctionTypes: []},
          location: {geoCriteriaIds: []},
          platform: {platforms: []},
          securityType: {securities: []}
        }
      ],
      details: [],
      type: ''
    }
  ],
  creativeId: '',
  dealsStatus: '',
  declaredClickThroughUrls: [],
  detectedAdvertiserIds: [],
  detectedDomains: [],
  detectedLanguages: [],
  detectedProductCategories: [],
  detectedSensitiveCategories: [],
  html: {height: 0, snippet: '', width: 0},
  impressionTrackingUrls: [],
  native: {
    advertiserName: '',
    appIcon: {height: 0, url: '', width: 0},
    body: '',
    callToAction: '',
    clickLinkUrl: '',
    clickTrackingUrl: '',
    headline: '',
    image: {},
    logo: {},
    priceDisplayText: '',
    starRating: '',
    storeUrl: '',
    videoUrl: ''
  },
  openAuctionStatus: '',
  restrictedCategories: [],
  servingRestrictions: [
    {
      contexts: [{}],
      disapproval: {details: [], reason: ''},
      disapprovalReasons: [{}],
      status: ''
    }
  ],
  vendorIds: [],
  version: 0,
  video: {videoUrl: '', videoVastXml: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives',
  headers: {'content-type': 'application/json'},
  body: {
    accountId: '',
    adChoicesDestinationUrl: '',
    adTechnologyProviders: {detectedProviderIds: [], hasUnidentifiedProvider: false},
    advertiserName: '',
    agencyId: '',
    apiUpdateTime: '',
    attributes: [],
    clickThroughUrls: [],
    corrections: [
      {
        contexts: [
          {
            all: '',
            appType: {appTypes: []},
            auctionType: {auctionTypes: []},
            location: {geoCriteriaIds: []},
            platform: {platforms: []},
            securityType: {securities: []}
          }
        ],
        details: [],
        type: ''
      }
    ],
    creativeId: '',
    dealsStatus: '',
    declaredClickThroughUrls: [],
    detectedAdvertiserIds: [],
    detectedDomains: [],
    detectedLanguages: [],
    detectedProductCategories: [],
    detectedSensitiveCategories: [],
    html: {height: 0, snippet: '', width: 0},
    impressionTrackingUrls: [],
    native: {
      advertiserName: '',
      appIcon: {height: 0, url: '', width: 0},
      body: '',
      callToAction: '',
      clickLinkUrl: '',
      clickTrackingUrl: '',
      headline: '',
      image: {},
      logo: {},
      priceDisplayText: '',
      starRating: '',
      storeUrl: '',
      videoUrl: ''
    },
    openAuctionStatus: '',
    restrictedCategories: [],
    servingRestrictions: [
      {
        contexts: [{}],
        disapproval: {details: [], reason: ''},
        disapprovalReasons: [{}],
        status: ''
      }
    ],
    vendorIds: [],
    version: 0,
    video: {videoUrl: '', videoVastXml: ''}
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives');

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

req.type('json');
req.send({
  accountId: '',
  adChoicesDestinationUrl: '',
  adTechnologyProviders: {
    detectedProviderIds: [],
    hasUnidentifiedProvider: false
  },
  advertiserName: '',
  agencyId: '',
  apiUpdateTime: '',
  attributes: [],
  clickThroughUrls: [],
  corrections: [
    {
      contexts: [
        {
          all: '',
          appType: {
            appTypes: []
          },
          auctionType: {
            auctionTypes: []
          },
          location: {
            geoCriteriaIds: []
          },
          platform: {
            platforms: []
          },
          securityType: {
            securities: []
          }
        }
      ],
      details: [],
      type: ''
    }
  ],
  creativeId: '',
  dealsStatus: '',
  declaredClickThroughUrls: [],
  detectedAdvertiserIds: [],
  detectedDomains: [],
  detectedLanguages: [],
  detectedProductCategories: [],
  detectedSensitiveCategories: [],
  html: {
    height: 0,
    snippet: '',
    width: 0
  },
  impressionTrackingUrls: [],
  native: {
    advertiserName: '',
    appIcon: {
      height: 0,
      url: '',
      width: 0
    },
    body: '',
    callToAction: '',
    clickLinkUrl: '',
    clickTrackingUrl: '',
    headline: '',
    image: {},
    logo: {},
    priceDisplayText: '',
    starRating: '',
    storeUrl: '',
    videoUrl: ''
  },
  openAuctionStatus: '',
  restrictedCategories: [],
  servingRestrictions: [
    {
      contexts: [
        {}
      ],
      disapproval: {
        details: [],
        reason: ''
      },
      disapprovalReasons: [
        {}
      ],
      status: ''
    }
  ],
  vendorIds: [],
  version: 0,
  video: {
    videoUrl: '',
    videoVastXml: ''
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives',
  headers: {'content-type': 'application/json'},
  data: {
    accountId: '',
    adChoicesDestinationUrl: '',
    adTechnologyProviders: {detectedProviderIds: [], hasUnidentifiedProvider: false},
    advertiserName: '',
    agencyId: '',
    apiUpdateTime: '',
    attributes: [],
    clickThroughUrls: [],
    corrections: [
      {
        contexts: [
          {
            all: '',
            appType: {appTypes: []},
            auctionType: {auctionTypes: []},
            location: {geoCriteriaIds: []},
            platform: {platforms: []},
            securityType: {securities: []}
          }
        ],
        details: [],
        type: ''
      }
    ],
    creativeId: '',
    dealsStatus: '',
    declaredClickThroughUrls: [],
    detectedAdvertiserIds: [],
    detectedDomains: [],
    detectedLanguages: [],
    detectedProductCategories: [],
    detectedSensitiveCategories: [],
    html: {height: 0, snippet: '', width: 0},
    impressionTrackingUrls: [],
    native: {
      advertiserName: '',
      appIcon: {height: 0, url: '', width: 0},
      body: '',
      callToAction: '',
      clickLinkUrl: '',
      clickTrackingUrl: '',
      headline: '',
      image: {},
      logo: {},
      priceDisplayText: '',
      starRating: '',
      storeUrl: '',
      videoUrl: ''
    },
    openAuctionStatus: '',
    restrictedCategories: [],
    servingRestrictions: [
      {
        contexts: [{}],
        disapproval: {details: [], reason: ''},
        disapprovalReasons: [{}],
        status: ''
      }
    ],
    vendorIds: [],
    version: 0,
    video: {videoUrl: '', videoVastXml: ''}
  }
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"accountId":"","adChoicesDestinationUrl":"","adTechnologyProviders":{"detectedProviderIds":[],"hasUnidentifiedProvider":false},"advertiserName":"","agencyId":"","apiUpdateTime":"","attributes":[],"clickThroughUrls":[],"corrections":[{"contexts":[{"all":"","appType":{"appTypes":[]},"auctionType":{"auctionTypes":[]},"location":{"geoCriteriaIds":[]},"platform":{"platforms":[]},"securityType":{"securities":[]}}],"details":[],"type":""}],"creativeId":"","dealsStatus":"","declaredClickThroughUrls":[],"detectedAdvertiserIds":[],"detectedDomains":[],"detectedLanguages":[],"detectedProductCategories":[],"detectedSensitiveCategories":[],"html":{"height":0,"snippet":"","width":0},"impressionTrackingUrls":[],"native":{"advertiserName":"","appIcon":{"height":0,"url":"","width":0},"body":"","callToAction":"","clickLinkUrl":"","clickTrackingUrl":"","headline":"","image":{},"logo":{},"priceDisplayText":"","starRating":"","storeUrl":"","videoUrl":""},"openAuctionStatus":"","restrictedCategories":[],"servingRestrictions":[{"contexts":[{}],"disapproval":{"details":[],"reason":""},"disapprovalReasons":[{}],"status":""}],"vendorIds":[],"version":0,"video":{"videoUrl":"","videoVastXml":""}}'
};

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 = @{ @"accountId": @"",
                              @"adChoicesDestinationUrl": @"",
                              @"adTechnologyProviders": @{ @"detectedProviderIds": @[  ], @"hasUnidentifiedProvider": @NO },
                              @"advertiserName": @"",
                              @"agencyId": @"",
                              @"apiUpdateTime": @"",
                              @"attributes": @[  ],
                              @"clickThroughUrls": @[  ],
                              @"corrections": @[ @{ @"contexts": @[ @{ @"all": @"", @"appType": @{ @"appTypes": @[  ] }, @"auctionType": @{ @"auctionTypes": @[  ] }, @"location": @{ @"geoCriteriaIds": @[  ] }, @"platform": @{ @"platforms": @[  ] }, @"securityType": @{ @"securities": @[  ] } } ], @"details": @[  ], @"type": @"" } ],
                              @"creativeId": @"",
                              @"dealsStatus": @"",
                              @"declaredClickThroughUrls": @[  ],
                              @"detectedAdvertiserIds": @[  ],
                              @"detectedDomains": @[  ],
                              @"detectedLanguages": @[  ],
                              @"detectedProductCategories": @[  ],
                              @"detectedSensitiveCategories": @[  ],
                              @"html": @{ @"height": @0, @"snippet": @"", @"width": @0 },
                              @"impressionTrackingUrls": @[  ],
                              @"native": @{ @"advertiserName": @"", @"appIcon": @{ @"height": @0, @"url": @"", @"width": @0 }, @"body": @"", @"callToAction": @"", @"clickLinkUrl": @"", @"clickTrackingUrl": @"", @"headline": @"", @"image": @{  }, @"logo": @{  }, @"priceDisplayText": @"", @"starRating": @"", @"storeUrl": @"", @"videoUrl": @"" },
                              @"openAuctionStatus": @"",
                              @"restrictedCategories": @[  ],
                              @"servingRestrictions": @[ @{ @"contexts": @[ @{  } ], @"disapproval": @{ @"details": @[  ], @"reason": @"" }, @"disapprovalReasons": @[ @{  } ], @"status": @"" } ],
                              @"vendorIds": @[  ],
                              @"version": @0,
                              @"video": @{ @"videoUrl": @"", @"videoVastXml": @"" } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/creatives" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/creatives",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'accountId' => '',
    'adChoicesDestinationUrl' => '',
    'adTechnologyProviders' => [
        'detectedProviderIds' => [
                
        ],
        'hasUnidentifiedProvider' => null
    ],
    'advertiserName' => '',
    'agencyId' => '',
    'apiUpdateTime' => '',
    'attributes' => [
        
    ],
    'clickThroughUrls' => [
        
    ],
    'corrections' => [
        [
                'contexts' => [
                                [
                                                                'all' => '',
                                                                'appType' => [
                                                                                                                                'appTypes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'auctionType' => [
                                                                                                                                'auctionTypes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'location' => [
                                                                                                                                'geoCriteriaIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'platform' => [
                                                                                                                                'platforms' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'securityType' => [
                                                                                                                                'securities' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'details' => [
                                
                ],
                'type' => ''
        ]
    ],
    'creativeId' => '',
    'dealsStatus' => '',
    'declaredClickThroughUrls' => [
        
    ],
    'detectedAdvertiserIds' => [
        
    ],
    'detectedDomains' => [
        
    ],
    'detectedLanguages' => [
        
    ],
    'detectedProductCategories' => [
        
    ],
    'detectedSensitiveCategories' => [
        
    ],
    'html' => [
        'height' => 0,
        'snippet' => '',
        'width' => 0
    ],
    'impressionTrackingUrls' => [
        
    ],
    'native' => [
        'advertiserName' => '',
        'appIcon' => [
                'height' => 0,
                'url' => '',
                'width' => 0
        ],
        'body' => '',
        'callToAction' => '',
        'clickLinkUrl' => '',
        'clickTrackingUrl' => '',
        'headline' => '',
        'image' => [
                
        ],
        'logo' => [
                
        ],
        'priceDisplayText' => '',
        'starRating' => '',
        'storeUrl' => '',
        'videoUrl' => ''
    ],
    'openAuctionStatus' => '',
    'restrictedCategories' => [
        
    ],
    'servingRestrictions' => [
        [
                'contexts' => [
                                [
                                                                
                                ]
                ],
                'disapproval' => [
                                'details' => [
                                                                
                                ],
                                'reason' => ''
                ],
                'disapprovalReasons' => [
                                [
                                                                
                                ]
                ],
                'status' => ''
        ]
    ],
    'vendorIds' => [
        
    ],
    'version' => 0,
    'video' => [
        'videoUrl' => '',
        'videoVastXml' => ''
    ]
  ]),
  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}}/v2beta1/accounts/:accountId/creatives', [
  'body' => '{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'accountId' => '',
  'adChoicesDestinationUrl' => '',
  'adTechnologyProviders' => [
    'detectedProviderIds' => [
        
    ],
    'hasUnidentifiedProvider' => null
  ],
  'advertiserName' => '',
  'agencyId' => '',
  'apiUpdateTime' => '',
  'attributes' => [
    
  ],
  'clickThroughUrls' => [
    
  ],
  'corrections' => [
    [
        'contexts' => [
                [
                                'all' => '',
                                'appType' => [
                                                                'appTypes' => [
                                                                                                                                
                                                                ]
                                ],
                                'auctionType' => [
                                                                'auctionTypes' => [
                                                                                                                                
                                                                ]
                                ],
                                'location' => [
                                                                'geoCriteriaIds' => [
                                                                                                                                
                                                                ]
                                ],
                                'platform' => [
                                                                'platforms' => [
                                                                                                                                
                                                                ]
                                ],
                                'securityType' => [
                                                                'securities' => [
                                                                                                                                
                                                                ]
                                ]
                ]
        ],
        'details' => [
                
        ],
        'type' => ''
    ]
  ],
  'creativeId' => '',
  'dealsStatus' => '',
  'declaredClickThroughUrls' => [
    
  ],
  'detectedAdvertiserIds' => [
    
  ],
  'detectedDomains' => [
    
  ],
  'detectedLanguages' => [
    
  ],
  'detectedProductCategories' => [
    
  ],
  'detectedSensitiveCategories' => [
    
  ],
  'html' => [
    'height' => 0,
    'snippet' => '',
    'width' => 0
  ],
  'impressionTrackingUrls' => [
    
  ],
  'native' => [
    'advertiserName' => '',
    'appIcon' => [
        'height' => 0,
        'url' => '',
        'width' => 0
    ],
    'body' => '',
    'callToAction' => '',
    'clickLinkUrl' => '',
    'clickTrackingUrl' => '',
    'headline' => '',
    'image' => [
        
    ],
    'logo' => [
        
    ],
    'priceDisplayText' => '',
    'starRating' => '',
    'storeUrl' => '',
    'videoUrl' => ''
  ],
  'openAuctionStatus' => '',
  'restrictedCategories' => [
    
  ],
  'servingRestrictions' => [
    [
        'contexts' => [
                [
                                
                ]
        ],
        'disapproval' => [
                'details' => [
                                
                ],
                'reason' => ''
        ],
        'disapprovalReasons' => [
                [
                                
                ]
        ],
        'status' => ''
    ]
  ],
  'vendorIds' => [
    
  ],
  'version' => 0,
  'video' => [
    'videoUrl' => '',
    'videoVastXml' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'accountId' => '',
  'adChoicesDestinationUrl' => '',
  'adTechnologyProviders' => [
    'detectedProviderIds' => [
        
    ],
    'hasUnidentifiedProvider' => null
  ],
  'advertiserName' => '',
  'agencyId' => '',
  'apiUpdateTime' => '',
  'attributes' => [
    
  ],
  'clickThroughUrls' => [
    
  ],
  'corrections' => [
    [
        'contexts' => [
                [
                                'all' => '',
                                'appType' => [
                                                                'appTypes' => [
                                                                                                                                
                                                                ]
                                ],
                                'auctionType' => [
                                                                'auctionTypes' => [
                                                                                                                                
                                                                ]
                                ],
                                'location' => [
                                                                'geoCriteriaIds' => [
                                                                                                                                
                                                                ]
                                ],
                                'platform' => [
                                                                'platforms' => [
                                                                                                                                
                                                                ]
                                ],
                                'securityType' => [
                                                                'securities' => [
                                                                                                                                
                                                                ]
                                ]
                ]
        ],
        'details' => [
                
        ],
        'type' => ''
    ]
  ],
  'creativeId' => '',
  'dealsStatus' => '',
  'declaredClickThroughUrls' => [
    
  ],
  'detectedAdvertiserIds' => [
    
  ],
  'detectedDomains' => [
    
  ],
  'detectedLanguages' => [
    
  ],
  'detectedProductCategories' => [
    
  ],
  'detectedSensitiveCategories' => [
    
  ],
  'html' => [
    'height' => 0,
    'snippet' => '',
    'width' => 0
  ],
  'impressionTrackingUrls' => [
    
  ],
  'native' => [
    'advertiserName' => '',
    'appIcon' => [
        'height' => 0,
        'url' => '',
        'width' => 0
    ],
    'body' => '',
    'callToAction' => '',
    'clickLinkUrl' => '',
    'clickTrackingUrl' => '',
    'headline' => '',
    'image' => [
        
    ],
    'logo' => [
        
    ],
    'priceDisplayText' => '',
    'starRating' => '',
    'storeUrl' => '',
    'videoUrl' => ''
  ],
  'openAuctionStatus' => '',
  'restrictedCategories' => [
    
  ],
  'servingRestrictions' => [
    [
        'contexts' => [
                [
                                
                ]
        ],
        'disapproval' => [
                'details' => [
                                
                ],
                'reason' => ''
        ],
        'disapprovalReasons' => [
                [
                                
                ]
        ],
        'status' => ''
    ]
  ],
  'vendorIds' => [
    
  ],
  'version' => 0,
  'video' => [
    'videoUrl' => '',
    'videoVastXml' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives');
$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}}/v2beta1/accounts/:accountId/creatives' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/creatives' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}'
import http.client

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

payload = "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}"

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

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/creatives", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives"

payload = {
    "accountId": "",
    "adChoicesDestinationUrl": "",
    "adTechnologyProviders": {
        "detectedProviderIds": [],
        "hasUnidentifiedProvider": False
    },
    "advertiserName": "",
    "agencyId": "",
    "apiUpdateTime": "",
    "attributes": [],
    "clickThroughUrls": [],
    "corrections": [
        {
            "contexts": [
                {
                    "all": "",
                    "appType": { "appTypes": [] },
                    "auctionType": { "auctionTypes": [] },
                    "location": { "geoCriteriaIds": [] },
                    "platform": { "platforms": [] },
                    "securityType": { "securities": [] }
                }
            ],
            "details": [],
            "type": ""
        }
    ],
    "creativeId": "",
    "dealsStatus": "",
    "declaredClickThroughUrls": [],
    "detectedAdvertiserIds": [],
    "detectedDomains": [],
    "detectedLanguages": [],
    "detectedProductCategories": [],
    "detectedSensitiveCategories": [],
    "html": {
        "height": 0,
        "snippet": "",
        "width": 0
    },
    "impressionTrackingUrls": [],
    "native": {
        "advertiserName": "",
        "appIcon": {
            "height": 0,
            "url": "",
            "width": 0
        },
        "body": "",
        "callToAction": "",
        "clickLinkUrl": "",
        "clickTrackingUrl": "",
        "headline": "",
        "image": {},
        "logo": {},
        "priceDisplayText": "",
        "starRating": "",
        "storeUrl": "",
        "videoUrl": ""
    },
    "openAuctionStatus": "",
    "restrictedCategories": [],
    "servingRestrictions": [
        {
            "contexts": [{}],
            "disapproval": {
                "details": [],
                "reason": ""
            },
            "disapprovalReasons": [{}],
            "status": ""
        }
    ],
    "vendorIds": [],
    "version": 0,
    "video": {
        "videoUrl": "",
        "videoVastXml": ""
    }
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/creatives"

payload <- "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/creatives")

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  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}"

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

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

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/creatives') do |req|
  req.body = "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}"
end

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

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

    let payload = json!({
        "accountId": "",
        "adChoicesDestinationUrl": "",
        "adTechnologyProviders": json!({
            "detectedProviderIds": (),
            "hasUnidentifiedProvider": false
        }),
        "advertiserName": "",
        "agencyId": "",
        "apiUpdateTime": "",
        "attributes": (),
        "clickThroughUrls": (),
        "corrections": (
            json!({
                "contexts": (
                    json!({
                        "all": "",
                        "appType": json!({"appTypes": ()}),
                        "auctionType": json!({"auctionTypes": ()}),
                        "location": json!({"geoCriteriaIds": ()}),
                        "platform": json!({"platforms": ()}),
                        "securityType": json!({"securities": ()})
                    })
                ),
                "details": (),
                "type": ""
            })
        ),
        "creativeId": "",
        "dealsStatus": "",
        "declaredClickThroughUrls": (),
        "detectedAdvertiserIds": (),
        "detectedDomains": (),
        "detectedLanguages": (),
        "detectedProductCategories": (),
        "detectedSensitiveCategories": (),
        "html": json!({
            "height": 0,
            "snippet": "",
            "width": 0
        }),
        "impressionTrackingUrls": (),
        "native": json!({
            "advertiserName": "",
            "appIcon": json!({
                "height": 0,
                "url": "",
                "width": 0
            }),
            "body": "",
            "callToAction": "",
            "clickLinkUrl": "",
            "clickTrackingUrl": "",
            "headline": "",
            "image": json!({}),
            "logo": json!({}),
            "priceDisplayText": "",
            "starRating": "",
            "storeUrl": "",
            "videoUrl": ""
        }),
        "openAuctionStatus": "",
        "restrictedCategories": (),
        "servingRestrictions": (
            json!({
                "contexts": (json!({})),
                "disapproval": json!({
                    "details": (),
                    "reason": ""
                }),
                "disapprovalReasons": (json!({})),
                "status": ""
            })
        ),
        "vendorIds": (),
        "version": 0,
        "video": json!({
            "videoUrl": "",
            "videoVastXml": ""
        })
    });

    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}}/v2beta1/accounts/:accountId/creatives \
  --header 'content-type: application/json' \
  --data '{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}'
echo '{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/creatives \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "accountId": "",\n  "adChoicesDestinationUrl": "",\n  "adTechnologyProviders": {\n    "detectedProviderIds": [],\n    "hasUnidentifiedProvider": false\n  },\n  "advertiserName": "",\n  "agencyId": "",\n  "apiUpdateTime": "",\n  "attributes": [],\n  "clickThroughUrls": [],\n  "corrections": [\n    {\n      "contexts": [\n        {\n          "all": "",\n          "appType": {\n            "appTypes": []\n          },\n          "auctionType": {\n            "auctionTypes": []\n          },\n          "location": {\n            "geoCriteriaIds": []\n          },\n          "platform": {\n            "platforms": []\n          },\n          "securityType": {\n            "securities": []\n          }\n        }\n      ],\n      "details": [],\n      "type": ""\n    }\n  ],\n  "creativeId": "",\n  "dealsStatus": "",\n  "declaredClickThroughUrls": [],\n  "detectedAdvertiserIds": [],\n  "detectedDomains": [],\n  "detectedLanguages": [],\n  "detectedProductCategories": [],\n  "detectedSensitiveCategories": [],\n  "html": {\n    "height": 0,\n    "snippet": "",\n    "width": 0\n  },\n  "impressionTrackingUrls": [],\n  "native": {\n    "advertiserName": "",\n    "appIcon": {\n      "height": 0,\n      "url": "",\n      "width": 0\n    },\n    "body": "",\n    "callToAction": "",\n    "clickLinkUrl": "",\n    "clickTrackingUrl": "",\n    "headline": "",\n    "image": {},\n    "logo": {},\n    "priceDisplayText": "",\n    "starRating": "",\n    "storeUrl": "",\n    "videoUrl": ""\n  },\n  "openAuctionStatus": "",\n  "restrictedCategories": [],\n  "servingRestrictions": [\n    {\n      "contexts": [\n        {}\n      ],\n      "disapproval": {\n        "details": [],\n        "reason": ""\n      },\n      "disapprovalReasons": [\n        {}\n      ],\n      "status": ""\n    }\n  ],\n  "vendorIds": [],\n  "version": 0,\n  "video": {\n    "videoUrl": "",\n    "videoVastXml": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/creatives
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": [
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  ],
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    [
      "contexts": [
        [
          "all": "",
          "appType": ["appTypes": []],
          "auctionType": ["auctionTypes": []],
          "location": ["geoCriteriaIds": []],
          "platform": ["platforms": []],
          "securityType": ["securities": []]
        ]
      ],
      "details": [],
      "type": ""
    ]
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": [
    "height": 0,
    "snippet": "",
    "width": 0
  ],
  "impressionTrackingUrls": [],
  "native": [
    "advertiserName": "",
    "appIcon": [
      "height": 0,
      "url": "",
      "width": 0
    ],
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": [],
    "logo": [],
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  ],
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    [
      "contexts": [[]],
      "disapproval": [
        "details": [],
        "reason": ""
      ],
      "disapprovalReasons": [[]],
      "status": ""
    ]
  ],
  "vendorIds": [],
  "version": 0,
  "video": [
    "videoUrl": "",
    "videoVastXml": ""
  ]
] as [String : Any]

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

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

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

dataTask.resume()
POST adexchangebuyer2.accounts.creatives.dealAssociations.add
{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add
QUERY PARAMS

accountId
creativeId
BODY json

{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}");

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

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add" {:content-type :json
                                                                                                                   :form-params {:association {:accountId ""
                                                                                                                                               :creativeId ""
                                                                                                                                               :dealsId ""}}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add"),
    Content = new StringContent("{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\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}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add"

	payload := strings.NewReader("{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 87

{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\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  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add")
  .header("content-type", "application/json")
  .body("{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  association: {
    accountId: '',
    creativeId: '',
    dealsId: ''
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add',
  headers: {'content-type': 'application/json'},
  data: {association: {accountId: '', creativeId: '', dealsId: ''}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"association":{"accountId":"","creativeId":"","dealsId":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "association": {\n    "accountId": "",\n    "creativeId": "",\n    "dealsId": ""\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  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({association: {accountId: '', creativeId: '', dealsId: ''}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add',
  headers: {'content-type': 'application/json'},
  body: {association: {accountId: '', creativeId: '', dealsId: ''}},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add');

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

req.type('json');
req.send({
  association: {
    accountId: '',
    creativeId: '',
    dealsId: ''
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add',
  headers: {'content-type': 'application/json'},
  data: {association: {accountId: '', creativeId: '', dealsId: ''}}
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"association":{"accountId":"","creativeId":"","dealsId":""}}'
};

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 = @{ @"association": @{ @"accountId": @"", @"creativeId": @"", @"dealsId": @"" } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'association' => [
        'accountId' => '',
        'creativeId' => '',
        'dealsId' => ''
    ]
  ]),
  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}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add', [
  'body' => '{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'association' => [
    'accountId' => '',
    'creativeId' => '',
    'dealsId' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'association' => [
    'accountId' => '',
    'creativeId' => '',
    'dealsId' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}'
import http.client

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

payload = "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}"

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

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add"

payload = { "association": {
        "accountId": "",
        "creativeId": "",
        "dealsId": ""
    } }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add"

payload <- "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}"

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

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

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add') do |req|
  req.body = "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add";

    let payload = json!({"association": json!({
            "accountId": "",
            "creativeId": "",
            "dealsId": ""
        })});

    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}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add \
  --header 'content-type: application/json' \
  --data '{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}'
echo '{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "association": {\n    "accountId": "",\n    "creativeId": "",\n    "dealsId": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["association": [
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  ]] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:add")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
GET adexchangebuyer2.accounts.creatives.dealAssociations.list
{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations
QUERY PARAMS

accountId
creativeId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations"

	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/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations';
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}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations"]
                                                       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}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations")

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/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations";

    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}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations
http GET {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations")! 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 adexchangebuyer2.accounts.creatives.dealAssociations.remove
{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove
QUERY PARAMS

accountId
creativeId
BODY json

{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove");

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  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}");

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

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove" {:content-type :json
                                                                                                                      :form-params {:association {:accountId ""
                                                                                                                                                  :creativeId ""
                                                                                                                                                  :dealsId ""}}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove"),
    Content = new StringContent("{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\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}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove"

	payload := strings.NewReader("{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 87

{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\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  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove")
  .header("content-type", "application/json")
  .body("{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  association: {
    accountId: '',
    creativeId: '',
    dealsId: ''
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove',
  headers: {'content-type': 'application/json'},
  data: {association: {accountId: '', creativeId: '', dealsId: ''}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"association":{"accountId":"","creativeId":"","dealsId":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "association": {\n    "accountId": "",\n    "creativeId": "",\n    "dealsId": ""\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  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove")
  .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/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove',
  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({association: {accountId: '', creativeId: '', dealsId: ''}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove',
  headers: {'content-type': 'application/json'},
  body: {association: {accountId: '', creativeId: '', dealsId: ''}},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove');

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

req.type('json');
req.send({
  association: {
    accountId: '',
    creativeId: '',
    dealsId: ''
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove',
  headers: {'content-type': 'application/json'},
  data: {association: {accountId: '', creativeId: '', dealsId: ''}}
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"association":{"accountId":"","creativeId":"","dealsId":""}}'
};

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 = @{ @"association": @{ @"accountId": @"", @"creativeId": @"", @"dealsId": @"" } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'association' => [
        'accountId' => '',
        'creativeId' => '',
        'dealsId' => ''
    ]
  ]),
  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}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove', [
  'body' => '{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'association' => [
    'accountId' => '',
    'creativeId' => '',
    'dealsId' => ''
  ]
]));

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

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

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

payload = "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}"

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

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove"

payload = { "association": {
        "accountId": "",
        "creativeId": "",
        "dealsId": ""
    } }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove"

payload <- "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove")

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  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}"

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

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

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove') do |req|
  req.body = "{\n  \"association\": {\n    \"accountId\": \"\",\n    \"creativeId\": \"\",\n    \"dealsId\": \"\"\n  }\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove";

    let payload = json!({"association": json!({
            "accountId": "",
            "creativeId": "",
            "dealsId": ""
        })});

    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}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove \
  --header 'content-type: application/json' \
  --data '{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}'
echo '{
  "association": {
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  }
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "association": {\n    "accountId": "",\n    "creativeId": "",\n    "dealsId": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["association": [
    "accountId": "",
    "creativeId": "",
    "dealsId": ""
  ]] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId/dealAssociations:remove")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
GET adexchangebuyer2.accounts.creatives.get
{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId
QUERY PARAMS

accountId
creativeId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId"

	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/v2beta1/accounts/:accountId/creatives/:creativeId HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId';
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}}/v2beta1/accounts/:accountId/creatives/:creativeId"]
                                                       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}}/v2beta1/accounts/:accountId/creatives/:creativeId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId")

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/v2beta1/accounts/:accountId/creatives/:creativeId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId";

    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}}/v2beta1/accounts/:accountId/creatives/:creativeId
http GET {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId")! 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 adexchangebuyer2.accounts.creatives.list
{{baseUrl}}/v2beta1/accounts/:accountId/creatives
QUERY PARAMS

accountId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/creatives");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/creatives")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/creatives"

	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/v2beta1/accounts/:accountId/creatives HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/creatives")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/creatives',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives';
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}}/v2beta1/accounts/:accountId/creatives"]
                                                       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}}/v2beta1/accounts/:accountId/creatives" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/creatives")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/creatives"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/creatives")

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/v2beta1/accounts/:accountId/creatives') do |req|
end

puts response.status
puts response.body
use reqwest;

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

    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}}/v2beta1/accounts/:accountId/creatives
http GET {{baseUrl}}/v2beta1/accounts/:accountId/creatives
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/creatives
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/creatives")! 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 adexchangebuyer2.accounts.creatives.stopWatching
{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching
QUERY PARAMS

accountId
creativeId
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching");

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, "{}");

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

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{}"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching"

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

	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/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching")
  .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/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching',
  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({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching',
  headers: {'content-type': 'application/json'},
  body: {},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching');

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching',
  headers: {'content-type': 'application/json'},
  data: {}
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

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

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

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching');
$request->setMethod(HTTP_METH_POST);

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

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

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

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

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

payload = "{}"

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

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching"

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

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching"

payload <- "{}"

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}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching")

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 = "{}"

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

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

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching') do |req|
  req.body = "{}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching";

    let payload = 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}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:stopWatching
import Foundation

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

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

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

let session = URLSession.shared
let dataTask = session.dataTask(with: request as 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 adexchangebuyer2.accounts.creatives.update
{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId
QUERY PARAMS

accountId
creativeId
BODY json

{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId");

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  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}");

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

(client/put "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId" {:content-type :json
                                                                                             :form-params {:accountId ""
                                                                                                           :adChoicesDestinationUrl ""
                                                                                                           :adTechnologyProviders {:detectedProviderIds []
                                                                                                                                   :hasUnidentifiedProvider false}
                                                                                                           :advertiserName ""
                                                                                                           :agencyId ""
                                                                                                           :apiUpdateTime ""
                                                                                                           :attributes []
                                                                                                           :clickThroughUrls []
                                                                                                           :corrections [{:contexts [{:all ""
                                                                                                                                      :appType {:appTypes []}
                                                                                                                                      :auctionType {:auctionTypes []}
                                                                                                                                      :location {:geoCriteriaIds []}
                                                                                                                                      :platform {:platforms []}
                                                                                                                                      :securityType {:securities []}}]
                                                                                                                          :details []
                                                                                                                          :type ""}]
                                                                                                           :creativeId ""
                                                                                                           :dealsStatus ""
                                                                                                           :declaredClickThroughUrls []
                                                                                                           :detectedAdvertiserIds []
                                                                                                           :detectedDomains []
                                                                                                           :detectedLanguages []
                                                                                                           :detectedProductCategories []
                                                                                                           :detectedSensitiveCategories []
                                                                                                           :html {:height 0
                                                                                                                  :snippet ""
                                                                                                                  :width 0}
                                                                                                           :impressionTrackingUrls []
                                                                                                           :native {:advertiserName ""
                                                                                                                    :appIcon {:height 0
                                                                                                                              :url ""
                                                                                                                              :width 0}
                                                                                                                    :body ""
                                                                                                                    :callToAction ""
                                                                                                                    :clickLinkUrl ""
                                                                                                                    :clickTrackingUrl ""
                                                                                                                    :headline ""
                                                                                                                    :image {}
                                                                                                                    :logo {}
                                                                                                                    :priceDisplayText ""
                                                                                                                    :starRating ""
                                                                                                                    :storeUrl ""
                                                                                                                    :videoUrl ""}
                                                                                                           :openAuctionStatus ""
                                                                                                           :restrictedCategories []
                                                                                                           :servingRestrictions [{:contexts [{}]
                                                                                                                                  :disapproval {:details []
                                                                                                                                                :reason ""}
                                                                                                                                  :disapprovalReasons [{}]
                                                                                                                                  :status ""}]
                                                                                                           :vendorIds []
                                                                                                           :version 0
                                                                                                           :video {:videoUrl ""
                                                                                                                   :videoVastXml ""}}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\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}}/v2beta1/accounts/:accountId/creatives/:creativeId"),
    Content = new StringContent("{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\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}}/v2beta1/accounts/:accountId/creatives/:creativeId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId"

	payload := strings.NewReader("{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\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/v2beta1/accounts/:accountId/creatives/:creativeId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1817

{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\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  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId")
  .header("content-type", "application/json")
  .body("{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  accountId: '',
  adChoicesDestinationUrl: '',
  adTechnologyProviders: {
    detectedProviderIds: [],
    hasUnidentifiedProvider: false
  },
  advertiserName: '',
  agencyId: '',
  apiUpdateTime: '',
  attributes: [],
  clickThroughUrls: [],
  corrections: [
    {
      contexts: [
        {
          all: '',
          appType: {
            appTypes: []
          },
          auctionType: {
            auctionTypes: []
          },
          location: {
            geoCriteriaIds: []
          },
          platform: {
            platforms: []
          },
          securityType: {
            securities: []
          }
        }
      ],
      details: [],
      type: ''
    }
  ],
  creativeId: '',
  dealsStatus: '',
  declaredClickThroughUrls: [],
  detectedAdvertiserIds: [],
  detectedDomains: [],
  detectedLanguages: [],
  detectedProductCategories: [],
  detectedSensitiveCategories: [],
  html: {
    height: 0,
    snippet: '',
    width: 0
  },
  impressionTrackingUrls: [],
  native: {
    advertiserName: '',
    appIcon: {
      height: 0,
      url: '',
      width: 0
    },
    body: '',
    callToAction: '',
    clickLinkUrl: '',
    clickTrackingUrl: '',
    headline: '',
    image: {},
    logo: {},
    priceDisplayText: '',
    starRating: '',
    storeUrl: '',
    videoUrl: ''
  },
  openAuctionStatus: '',
  restrictedCategories: [],
  servingRestrictions: [
    {
      contexts: [
        {}
      ],
      disapproval: {
        details: [],
        reason: ''
      },
      disapprovalReasons: [
        {}
      ],
      status: ''
    }
  ],
  vendorIds: [],
  version: 0,
  video: {
    videoUrl: '',
    videoVastXml: ''
  }
});

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

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

xhr.open('PUT', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId',
  headers: {'content-type': 'application/json'},
  data: {
    accountId: '',
    adChoicesDestinationUrl: '',
    adTechnologyProviders: {detectedProviderIds: [], hasUnidentifiedProvider: false},
    advertiserName: '',
    agencyId: '',
    apiUpdateTime: '',
    attributes: [],
    clickThroughUrls: [],
    corrections: [
      {
        contexts: [
          {
            all: '',
            appType: {appTypes: []},
            auctionType: {auctionTypes: []},
            location: {geoCriteriaIds: []},
            platform: {platforms: []},
            securityType: {securities: []}
          }
        ],
        details: [],
        type: ''
      }
    ],
    creativeId: '',
    dealsStatus: '',
    declaredClickThroughUrls: [],
    detectedAdvertiserIds: [],
    detectedDomains: [],
    detectedLanguages: [],
    detectedProductCategories: [],
    detectedSensitiveCategories: [],
    html: {height: 0, snippet: '', width: 0},
    impressionTrackingUrls: [],
    native: {
      advertiserName: '',
      appIcon: {height: 0, url: '', width: 0},
      body: '',
      callToAction: '',
      clickLinkUrl: '',
      clickTrackingUrl: '',
      headline: '',
      image: {},
      logo: {},
      priceDisplayText: '',
      starRating: '',
      storeUrl: '',
      videoUrl: ''
    },
    openAuctionStatus: '',
    restrictedCategories: [],
    servingRestrictions: [
      {
        contexts: [{}],
        disapproval: {details: [], reason: ''},
        disapprovalReasons: [{}],
        status: ''
      }
    ],
    vendorIds: [],
    version: 0,
    video: {videoUrl: '', videoVastXml: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"accountId":"","adChoicesDestinationUrl":"","adTechnologyProviders":{"detectedProviderIds":[],"hasUnidentifiedProvider":false},"advertiserName":"","agencyId":"","apiUpdateTime":"","attributes":[],"clickThroughUrls":[],"corrections":[{"contexts":[{"all":"","appType":{"appTypes":[]},"auctionType":{"auctionTypes":[]},"location":{"geoCriteriaIds":[]},"platform":{"platforms":[]},"securityType":{"securities":[]}}],"details":[],"type":""}],"creativeId":"","dealsStatus":"","declaredClickThroughUrls":[],"detectedAdvertiserIds":[],"detectedDomains":[],"detectedLanguages":[],"detectedProductCategories":[],"detectedSensitiveCategories":[],"html":{"height":0,"snippet":"","width":0},"impressionTrackingUrls":[],"native":{"advertiserName":"","appIcon":{"height":0,"url":"","width":0},"body":"","callToAction":"","clickLinkUrl":"","clickTrackingUrl":"","headline":"","image":{},"logo":{},"priceDisplayText":"","starRating":"","storeUrl":"","videoUrl":""},"openAuctionStatus":"","restrictedCategories":[],"servingRestrictions":[{"contexts":[{}],"disapproval":{"details":[],"reason":""},"disapprovalReasons":[{}],"status":""}],"vendorIds":[],"version":0,"video":{"videoUrl":"","videoVastXml":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "accountId": "",\n  "adChoicesDestinationUrl": "",\n  "adTechnologyProviders": {\n    "detectedProviderIds": [],\n    "hasUnidentifiedProvider": false\n  },\n  "advertiserName": "",\n  "agencyId": "",\n  "apiUpdateTime": "",\n  "attributes": [],\n  "clickThroughUrls": [],\n  "corrections": [\n    {\n      "contexts": [\n        {\n          "all": "",\n          "appType": {\n            "appTypes": []\n          },\n          "auctionType": {\n            "auctionTypes": []\n          },\n          "location": {\n            "geoCriteriaIds": []\n          },\n          "platform": {\n            "platforms": []\n          },\n          "securityType": {\n            "securities": []\n          }\n        }\n      ],\n      "details": [],\n      "type": ""\n    }\n  ],\n  "creativeId": "",\n  "dealsStatus": "",\n  "declaredClickThroughUrls": [],\n  "detectedAdvertiserIds": [],\n  "detectedDomains": [],\n  "detectedLanguages": [],\n  "detectedProductCategories": [],\n  "detectedSensitiveCategories": [],\n  "html": {\n    "height": 0,\n    "snippet": "",\n    "width": 0\n  },\n  "impressionTrackingUrls": [],\n  "native": {\n    "advertiserName": "",\n    "appIcon": {\n      "height": 0,\n      "url": "",\n      "width": 0\n    },\n    "body": "",\n    "callToAction": "",\n    "clickLinkUrl": "",\n    "clickTrackingUrl": "",\n    "headline": "",\n    "image": {},\n    "logo": {},\n    "priceDisplayText": "",\n    "starRating": "",\n    "storeUrl": "",\n    "videoUrl": ""\n  },\n  "openAuctionStatus": "",\n  "restrictedCategories": [],\n  "servingRestrictions": [\n    {\n      "contexts": [\n        {}\n      ],\n      "disapproval": {\n        "details": [],\n        "reason": ""\n      },\n      "disapprovalReasons": [\n        {}\n      ],\n      "status": ""\n    }\n  ],\n  "vendorIds": [],\n  "version": 0,\n  "video": {\n    "videoUrl": "",\n    "videoVastXml": ""\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  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId")
  .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/v2beta1/accounts/:accountId/creatives/:creativeId',
  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({
  accountId: '',
  adChoicesDestinationUrl: '',
  adTechnologyProviders: {detectedProviderIds: [], hasUnidentifiedProvider: false},
  advertiserName: '',
  agencyId: '',
  apiUpdateTime: '',
  attributes: [],
  clickThroughUrls: [],
  corrections: [
    {
      contexts: [
        {
          all: '',
          appType: {appTypes: []},
          auctionType: {auctionTypes: []},
          location: {geoCriteriaIds: []},
          platform: {platforms: []},
          securityType: {securities: []}
        }
      ],
      details: [],
      type: ''
    }
  ],
  creativeId: '',
  dealsStatus: '',
  declaredClickThroughUrls: [],
  detectedAdvertiserIds: [],
  detectedDomains: [],
  detectedLanguages: [],
  detectedProductCategories: [],
  detectedSensitiveCategories: [],
  html: {height: 0, snippet: '', width: 0},
  impressionTrackingUrls: [],
  native: {
    advertiserName: '',
    appIcon: {height: 0, url: '', width: 0},
    body: '',
    callToAction: '',
    clickLinkUrl: '',
    clickTrackingUrl: '',
    headline: '',
    image: {},
    logo: {},
    priceDisplayText: '',
    starRating: '',
    storeUrl: '',
    videoUrl: ''
  },
  openAuctionStatus: '',
  restrictedCategories: [],
  servingRestrictions: [
    {
      contexts: [{}],
      disapproval: {details: [], reason: ''},
      disapprovalReasons: [{}],
      status: ''
    }
  ],
  vendorIds: [],
  version: 0,
  video: {videoUrl: '', videoVastXml: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId',
  headers: {'content-type': 'application/json'},
  body: {
    accountId: '',
    adChoicesDestinationUrl: '',
    adTechnologyProviders: {detectedProviderIds: [], hasUnidentifiedProvider: false},
    advertiserName: '',
    agencyId: '',
    apiUpdateTime: '',
    attributes: [],
    clickThroughUrls: [],
    corrections: [
      {
        contexts: [
          {
            all: '',
            appType: {appTypes: []},
            auctionType: {auctionTypes: []},
            location: {geoCriteriaIds: []},
            platform: {platforms: []},
            securityType: {securities: []}
          }
        ],
        details: [],
        type: ''
      }
    ],
    creativeId: '',
    dealsStatus: '',
    declaredClickThroughUrls: [],
    detectedAdvertiserIds: [],
    detectedDomains: [],
    detectedLanguages: [],
    detectedProductCategories: [],
    detectedSensitiveCategories: [],
    html: {height: 0, snippet: '', width: 0},
    impressionTrackingUrls: [],
    native: {
      advertiserName: '',
      appIcon: {height: 0, url: '', width: 0},
      body: '',
      callToAction: '',
      clickLinkUrl: '',
      clickTrackingUrl: '',
      headline: '',
      image: {},
      logo: {},
      priceDisplayText: '',
      starRating: '',
      storeUrl: '',
      videoUrl: ''
    },
    openAuctionStatus: '',
    restrictedCategories: [],
    servingRestrictions: [
      {
        contexts: [{}],
        disapproval: {details: [], reason: ''},
        disapprovalReasons: [{}],
        status: ''
      }
    ],
    vendorIds: [],
    version: 0,
    video: {videoUrl: '', videoVastXml: ''}
  },
  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}}/v2beta1/accounts/:accountId/creatives/:creativeId');

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

req.type('json');
req.send({
  accountId: '',
  adChoicesDestinationUrl: '',
  adTechnologyProviders: {
    detectedProviderIds: [],
    hasUnidentifiedProvider: false
  },
  advertiserName: '',
  agencyId: '',
  apiUpdateTime: '',
  attributes: [],
  clickThroughUrls: [],
  corrections: [
    {
      contexts: [
        {
          all: '',
          appType: {
            appTypes: []
          },
          auctionType: {
            auctionTypes: []
          },
          location: {
            geoCriteriaIds: []
          },
          platform: {
            platforms: []
          },
          securityType: {
            securities: []
          }
        }
      ],
      details: [],
      type: ''
    }
  ],
  creativeId: '',
  dealsStatus: '',
  declaredClickThroughUrls: [],
  detectedAdvertiserIds: [],
  detectedDomains: [],
  detectedLanguages: [],
  detectedProductCategories: [],
  detectedSensitiveCategories: [],
  html: {
    height: 0,
    snippet: '',
    width: 0
  },
  impressionTrackingUrls: [],
  native: {
    advertiserName: '',
    appIcon: {
      height: 0,
      url: '',
      width: 0
    },
    body: '',
    callToAction: '',
    clickLinkUrl: '',
    clickTrackingUrl: '',
    headline: '',
    image: {},
    logo: {},
    priceDisplayText: '',
    starRating: '',
    storeUrl: '',
    videoUrl: ''
  },
  openAuctionStatus: '',
  restrictedCategories: [],
  servingRestrictions: [
    {
      contexts: [
        {}
      ],
      disapproval: {
        details: [],
        reason: ''
      },
      disapprovalReasons: [
        {}
      ],
      status: ''
    }
  ],
  vendorIds: [],
  version: 0,
  video: {
    videoUrl: '',
    videoVastXml: ''
  }
});

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}}/v2beta1/accounts/:accountId/creatives/:creativeId',
  headers: {'content-type': 'application/json'},
  data: {
    accountId: '',
    adChoicesDestinationUrl: '',
    adTechnologyProviders: {detectedProviderIds: [], hasUnidentifiedProvider: false},
    advertiserName: '',
    agencyId: '',
    apiUpdateTime: '',
    attributes: [],
    clickThroughUrls: [],
    corrections: [
      {
        contexts: [
          {
            all: '',
            appType: {appTypes: []},
            auctionType: {auctionTypes: []},
            location: {geoCriteriaIds: []},
            platform: {platforms: []},
            securityType: {securities: []}
          }
        ],
        details: [],
        type: ''
      }
    ],
    creativeId: '',
    dealsStatus: '',
    declaredClickThroughUrls: [],
    detectedAdvertiserIds: [],
    detectedDomains: [],
    detectedLanguages: [],
    detectedProductCategories: [],
    detectedSensitiveCategories: [],
    html: {height: 0, snippet: '', width: 0},
    impressionTrackingUrls: [],
    native: {
      advertiserName: '',
      appIcon: {height: 0, url: '', width: 0},
      body: '',
      callToAction: '',
      clickLinkUrl: '',
      clickTrackingUrl: '',
      headline: '',
      image: {},
      logo: {},
      priceDisplayText: '',
      starRating: '',
      storeUrl: '',
      videoUrl: ''
    },
    openAuctionStatus: '',
    restrictedCategories: [],
    servingRestrictions: [
      {
        contexts: [{}],
        disapproval: {details: [], reason: ''},
        disapprovalReasons: [{}],
        status: ''
      }
    ],
    vendorIds: [],
    version: 0,
    video: {videoUrl: '', videoVastXml: ''}
  }
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"accountId":"","adChoicesDestinationUrl":"","adTechnologyProviders":{"detectedProviderIds":[],"hasUnidentifiedProvider":false},"advertiserName":"","agencyId":"","apiUpdateTime":"","attributes":[],"clickThroughUrls":[],"corrections":[{"contexts":[{"all":"","appType":{"appTypes":[]},"auctionType":{"auctionTypes":[]},"location":{"geoCriteriaIds":[]},"platform":{"platforms":[]},"securityType":{"securities":[]}}],"details":[],"type":""}],"creativeId":"","dealsStatus":"","declaredClickThroughUrls":[],"detectedAdvertiserIds":[],"detectedDomains":[],"detectedLanguages":[],"detectedProductCategories":[],"detectedSensitiveCategories":[],"html":{"height":0,"snippet":"","width":0},"impressionTrackingUrls":[],"native":{"advertiserName":"","appIcon":{"height":0,"url":"","width":0},"body":"","callToAction":"","clickLinkUrl":"","clickTrackingUrl":"","headline":"","image":{},"logo":{},"priceDisplayText":"","starRating":"","storeUrl":"","videoUrl":""},"openAuctionStatus":"","restrictedCategories":[],"servingRestrictions":[{"contexts":[{}],"disapproval":{"details":[],"reason":""},"disapprovalReasons":[{}],"status":""}],"vendorIds":[],"version":0,"video":{"videoUrl":"","videoVastXml":""}}'
};

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 = @{ @"accountId": @"",
                              @"adChoicesDestinationUrl": @"",
                              @"adTechnologyProviders": @{ @"detectedProviderIds": @[  ], @"hasUnidentifiedProvider": @NO },
                              @"advertiserName": @"",
                              @"agencyId": @"",
                              @"apiUpdateTime": @"",
                              @"attributes": @[  ],
                              @"clickThroughUrls": @[  ],
                              @"corrections": @[ @{ @"contexts": @[ @{ @"all": @"", @"appType": @{ @"appTypes": @[  ] }, @"auctionType": @{ @"auctionTypes": @[  ] }, @"location": @{ @"geoCriteriaIds": @[  ] }, @"platform": @{ @"platforms": @[  ] }, @"securityType": @{ @"securities": @[  ] } } ], @"details": @[  ], @"type": @"" } ],
                              @"creativeId": @"",
                              @"dealsStatus": @"",
                              @"declaredClickThroughUrls": @[  ],
                              @"detectedAdvertiserIds": @[  ],
                              @"detectedDomains": @[  ],
                              @"detectedLanguages": @[  ],
                              @"detectedProductCategories": @[  ],
                              @"detectedSensitiveCategories": @[  ],
                              @"html": @{ @"height": @0, @"snippet": @"", @"width": @0 },
                              @"impressionTrackingUrls": @[  ],
                              @"native": @{ @"advertiserName": @"", @"appIcon": @{ @"height": @0, @"url": @"", @"width": @0 }, @"body": @"", @"callToAction": @"", @"clickLinkUrl": @"", @"clickTrackingUrl": @"", @"headline": @"", @"image": @{  }, @"logo": @{  }, @"priceDisplayText": @"", @"starRating": @"", @"storeUrl": @"", @"videoUrl": @"" },
                              @"openAuctionStatus": @"",
                              @"restrictedCategories": @[  ],
                              @"servingRestrictions": @[ @{ @"contexts": @[ @{  } ], @"disapproval": @{ @"details": @[  ], @"reason": @"" }, @"disapprovalReasons": @[ @{  } ], @"status": @"" } ],
                              @"vendorIds": @[  ],
                              @"version": @0,
                              @"video": @{ @"videoUrl": @"", @"videoVastXml": @"" } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId"]
                                                       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}}/v2beta1/accounts/:accountId/creatives/:creativeId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId",
  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([
    'accountId' => '',
    'adChoicesDestinationUrl' => '',
    'adTechnologyProviders' => [
        'detectedProviderIds' => [
                
        ],
        'hasUnidentifiedProvider' => null
    ],
    'advertiserName' => '',
    'agencyId' => '',
    'apiUpdateTime' => '',
    'attributes' => [
        
    ],
    'clickThroughUrls' => [
        
    ],
    'corrections' => [
        [
                'contexts' => [
                                [
                                                                'all' => '',
                                                                'appType' => [
                                                                                                                                'appTypes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'auctionType' => [
                                                                                                                                'auctionTypes' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'location' => [
                                                                                                                                'geoCriteriaIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'platform' => [
                                                                                                                                'platforms' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'securityType' => [
                                                                                                                                'securities' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'details' => [
                                
                ],
                'type' => ''
        ]
    ],
    'creativeId' => '',
    'dealsStatus' => '',
    'declaredClickThroughUrls' => [
        
    ],
    'detectedAdvertiserIds' => [
        
    ],
    'detectedDomains' => [
        
    ],
    'detectedLanguages' => [
        
    ],
    'detectedProductCategories' => [
        
    ],
    'detectedSensitiveCategories' => [
        
    ],
    'html' => [
        'height' => 0,
        'snippet' => '',
        'width' => 0
    ],
    'impressionTrackingUrls' => [
        
    ],
    'native' => [
        'advertiserName' => '',
        'appIcon' => [
                'height' => 0,
                'url' => '',
                'width' => 0
        ],
        'body' => '',
        'callToAction' => '',
        'clickLinkUrl' => '',
        'clickTrackingUrl' => '',
        'headline' => '',
        'image' => [
                
        ],
        'logo' => [
                
        ],
        'priceDisplayText' => '',
        'starRating' => '',
        'storeUrl' => '',
        'videoUrl' => ''
    ],
    'openAuctionStatus' => '',
    'restrictedCategories' => [
        
    ],
    'servingRestrictions' => [
        [
                'contexts' => [
                                [
                                                                
                                ]
                ],
                'disapproval' => [
                                'details' => [
                                                                
                                ],
                                'reason' => ''
                ],
                'disapprovalReasons' => [
                                [
                                                                
                                ]
                ],
                'status' => ''
        ]
    ],
    'vendorIds' => [
        
    ],
    'version' => 0,
    'video' => [
        'videoUrl' => '',
        'videoVastXml' => ''
    ]
  ]),
  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}}/v2beta1/accounts/:accountId/creatives/:creativeId', [
  'body' => '{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId');
$request->setMethod(HTTP_METH_PUT);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'accountId' => '',
  'adChoicesDestinationUrl' => '',
  'adTechnologyProviders' => [
    'detectedProviderIds' => [
        
    ],
    'hasUnidentifiedProvider' => null
  ],
  'advertiserName' => '',
  'agencyId' => '',
  'apiUpdateTime' => '',
  'attributes' => [
    
  ],
  'clickThroughUrls' => [
    
  ],
  'corrections' => [
    [
        'contexts' => [
                [
                                'all' => '',
                                'appType' => [
                                                                'appTypes' => [
                                                                                                                                
                                                                ]
                                ],
                                'auctionType' => [
                                                                'auctionTypes' => [
                                                                                                                                
                                                                ]
                                ],
                                'location' => [
                                                                'geoCriteriaIds' => [
                                                                                                                                
                                                                ]
                                ],
                                'platform' => [
                                                                'platforms' => [
                                                                                                                                
                                                                ]
                                ],
                                'securityType' => [
                                                                'securities' => [
                                                                                                                                
                                                                ]
                                ]
                ]
        ],
        'details' => [
                
        ],
        'type' => ''
    ]
  ],
  'creativeId' => '',
  'dealsStatus' => '',
  'declaredClickThroughUrls' => [
    
  ],
  'detectedAdvertiserIds' => [
    
  ],
  'detectedDomains' => [
    
  ],
  'detectedLanguages' => [
    
  ],
  'detectedProductCategories' => [
    
  ],
  'detectedSensitiveCategories' => [
    
  ],
  'html' => [
    'height' => 0,
    'snippet' => '',
    'width' => 0
  ],
  'impressionTrackingUrls' => [
    
  ],
  'native' => [
    'advertiserName' => '',
    'appIcon' => [
        'height' => 0,
        'url' => '',
        'width' => 0
    ],
    'body' => '',
    'callToAction' => '',
    'clickLinkUrl' => '',
    'clickTrackingUrl' => '',
    'headline' => '',
    'image' => [
        
    ],
    'logo' => [
        
    ],
    'priceDisplayText' => '',
    'starRating' => '',
    'storeUrl' => '',
    'videoUrl' => ''
  ],
  'openAuctionStatus' => '',
  'restrictedCategories' => [
    
  ],
  'servingRestrictions' => [
    [
        'contexts' => [
                [
                                
                ]
        ],
        'disapproval' => [
                'details' => [
                                
                ],
                'reason' => ''
        ],
        'disapprovalReasons' => [
                [
                                
                ]
        ],
        'status' => ''
    ]
  ],
  'vendorIds' => [
    
  ],
  'version' => 0,
  'video' => [
    'videoUrl' => '',
    'videoVastXml' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'accountId' => '',
  'adChoicesDestinationUrl' => '',
  'adTechnologyProviders' => [
    'detectedProviderIds' => [
        
    ],
    'hasUnidentifiedProvider' => null
  ],
  'advertiserName' => '',
  'agencyId' => '',
  'apiUpdateTime' => '',
  'attributes' => [
    
  ],
  'clickThroughUrls' => [
    
  ],
  'corrections' => [
    [
        'contexts' => [
                [
                                'all' => '',
                                'appType' => [
                                                                'appTypes' => [
                                                                                                                                
                                                                ]
                                ],
                                'auctionType' => [
                                                                'auctionTypes' => [
                                                                                                                                
                                                                ]
                                ],
                                'location' => [
                                                                'geoCriteriaIds' => [
                                                                                                                                
                                                                ]
                                ],
                                'platform' => [
                                                                'platforms' => [
                                                                                                                                
                                                                ]
                                ],
                                'securityType' => [
                                                                'securities' => [
                                                                                                                                
                                                                ]
                                ]
                ]
        ],
        'details' => [
                
        ],
        'type' => ''
    ]
  ],
  'creativeId' => '',
  'dealsStatus' => '',
  'declaredClickThroughUrls' => [
    
  ],
  'detectedAdvertiserIds' => [
    
  ],
  'detectedDomains' => [
    
  ],
  'detectedLanguages' => [
    
  ],
  'detectedProductCategories' => [
    
  ],
  'detectedSensitiveCategories' => [
    
  ],
  'html' => [
    'height' => 0,
    'snippet' => '',
    'width' => 0
  ],
  'impressionTrackingUrls' => [
    
  ],
  'native' => [
    'advertiserName' => '',
    'appIcon' => [
        'height' => 0,
        'url' => '',
        'width' => 0
    ],
    'body' => '',
    'callToAction' => '',
    'clickLinkUrl' => '',
    'clickTrackingUrl' => '',
    'headline' => '',
    'image' => [
        
    ],
    'logo' => [
        
    ],
    'priceDisplayText' => '',
    'starRating' => '',
    'storeUrl' => '',
    'videoUrl' => ''
  ],
  'openAuctionStatus' => '',
  'restrictedCategories' => [
    
  ],
  'servingRestrictions' => [
    [
        'contexts' => [
                [
                                
                ]
        ],
        'disapproval' => [
                'details' => [
                                
                ],
                'reason' => ''
        ],
        'disapprovalReasons' => [
                [
                                
                ]
        ],
        'status' => ''
    ]
  ],
  'vendorIds' => [
    
  ],
  'version' => 0,
  'video' => [
    'videoUrl' => '',
    'videoVastXml' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId');
$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}}/v2beta1/accounts/:accountId/creatives/:creativeId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}'
import http.client

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

payload = "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\n  }\n}"

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

conn.request("PUT", "/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId"

payload = {
    "accountId": "",
    "adChoicesDestinationUrl": "",
    "adTechnologyProviders": {
        "detectedProviderIds": [],
        "hasUnidentifiedProvider": False
    },
    "advertiserName": "",
    "agencyId": "",
    "apiUpdateTime": "",
    "attributes": [],
    "clickThroughUrls": [],
    "corrections": [
        {
            "contexts": [
                {
                    "all": "",
                    "appType": { "appTypes": [] },
                    "auctionType": { "auctionTypes": [] },
                    "location": { "geoCriteriaIds": [] },
                    "platform": { "platforms": [] },
                    "securityType": { "securities": [] }
                }
            ],
            "details": [],
            "type": ""
        }
    ],
    "creativeId": "",
    "dealsStatus": "",
    "declaredClickThroughUrls": [],
    "detectedAdvertiserIds": [],
    "detectedDomains": [],
    "detectedLanguages": [],
    "detectedProductCategories": [],
    "detectedSensitiveCategories": [],
    "html": {
        "height": 0,
        "snippet": "",
        "width": 0
    },
    "impressionTrackingUrls": [],
    "native": {
        "advertiserName": "",
        "appIcon": {
            "height": 0,
            "url": "",
            "width": 0
        },
        "body": "",
        "callToAction": "",
        "clickLinkUrl": "",
        "clickTrackingUrl": "",
        "headline": "",
        "image": {},
        "logo": {},
        "priceDisplayText": "",
        "starRating": "",
        "storeUrl": "",
        "videoUrl": ""
    },
    "openAuctionStatus": "",
    "restrictedCategories": [],
    "servingRestrictions": [
        {
            "contexts": [{}],
            "disapproval": {
                "details": [],
                "reason": ""
            },
            "disapprovalReasons": [{}],
            "status": ""
        }
    ],
    "vendorIds": [],
    "version": 0,
    "video": {
        "videoUrl": "",
        "videoVastXml": ""
    }
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId"

payload <- "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\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}}/v2beta1/accounts/:accountId/creatives/:creativeId")

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  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\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/v2beta1/accounts/:accountId/creatives/:creativeId') do |req|
  req.body = "{\n  \"accountId\": \"\",\n  \"adChoicesDestinationUrl\": \"\",\n  \"adTechnologyProviders\": {\n    \"detectedProviderIds\": [],\n    \"hasUnidentifiedProvider\": false\n  },\n  \"advertiserName\": \"\",\n  \"agencyId\": \"\",\n  \"apiUpdateTime\": \"\",\n  \"attributes\": [],\n  \"clickThroughUrls\": [],\n  \"corrections\": [\n    {\n      \"contexts\": [\n        {\n          \"all\": \"\",\n          \"appType\": {\n            \"appTypes\": []\n          },\n          \"auctionType\": {\n            \"auctionTypes\": []\n          },\n          \"location\": {\n            \"geoCriteriaIds\": []\n          },\n          \"platform\": {\n            \"platforms\": []\n          },\n          \"securityType\": {\n            \"securities\": []\n          }\n        }\n      ],\n      \"details\": [],\n      \"type\": \"\"\n    }\n  ],\n  \"creativeId\": \"\",\n  \"dealsStatus\": \"\",\n  \"declaredClickThroughUrls\": [],\n  \"detectedAdvertiserIds\": [],\n  \"detectedDomains\": [],\n  \"detectedLanguages\": [],\n  \"detectedProductCategories\": [],\n  \"detectedSensitiveCategories\": [],\n  \"html\": {\n    \"height\": 0,\n    \"snippet\": \"\",\n    \"width\": 0\n  },\n  \"impressionTrackingUrls\": [],\n  \"native\": {\n    \"advertiserName\": \"\",\n    \"appIcon\": {\n      \"height\": 0,\n      \"url\": \"\",\n      \"width\": 0\n    },\n    \"body\": \"\",\n    \"callToAction\": \"\",\n    \"clickLinkUrl\": \"\",\n    \"clickTrackingUrl\": \"\",\n    \"headline\": \"\",\n    \"image\": {},\n    \"logo\": {},\n    \"priceDisplayText\": \"\",\n    \"starRating\": \"\",\n    \"storeUrl\": \"\",\n    \"videoUrl\": \"\"\n  },\n  \"openAuctionStatus\": \"\",\n  \"restrictedCategories\": [],\n  \"servingRestrictions\": [\n    {\n      \"contexts\": [\n        {}\n      ],\n      \"disapproval\": {\n        \"details\": [],\n        \"reason\": \"\"\n      },\n      \"disapprovalReasons\": [\n        {}\n      ],\n      \"status\": \"\"\n    }\n  ],\n  \"vendorIds\": [],\n  \"version\": 0,\n  \"video\": {\n    \"videoUrl\": \"\",\n    \"videoVastXml\": \"\"\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}}/v2beta1/accounts/:accountId/creatives/:creativeId";

    let payload = json!({
        "accountId": "",
        "adChoicesDestinationUrl": "",
        "adTechnologyProviders": json!({
            "detectedProviderIds": (),
            "hasUnidentifiedProvider": false
        }),
        "advertiserName": "",
        "agencyId": "",
        "apiUpdateTime": "",
        "attributes": (),
        "clickThroughUrls": (),
        "corrections": (
            json!({
                "contexts": (
                    json!({
                        "all": "",
                        "appType": json!({"appTypes": ()}),
                        "auctionType": json!({"auctionTypes": ()}),
                        "location": json!({"geoCriteriaIds": ()}),
                        "platform": json!({"platforms": ()}),
                        "securityType": json!({"securities": ()})
                    })
                ),
                "details": (),
                "type": ""
            })
        ),
        "creativeId": "",
        "dealsStatus": "",
        "declaredClickThroughUrls": (),
        "detectedAdvertiserIds": (),
        "detectedDomains": (),
        "detectedLanguages": (),
        "detectedProductCategories": (),
        "detectedSensitiveCategories": (),
        "html": json!({
            "height": 0,
            "snippet": "",
            "width": 0
        }),
        "impressionTrackingUrls": (),
        "native": json!({
            "advertiserName": "",
            "appIcon": json!({
                "height": 0,
                "url": "",
                "width": 0
            }),
            "body": "",
            "callToAction": "",
            "clickLinkUrl": "",
            "clickTrackingUrl": "",
            "headline": "",
            "image": json!({}),
            "logo": json!({}),
            "priceDisplayText": "",
            "starRating": "",
            "storeUrl": "",
            "videoUrl": ""
        }),
        "openAuctionStatus": "",
        "restrictedCategories": (),
        "servingRestrictions": (
            json!({
                "contexts": (json!({})),
                "disapproval": json!({
                    "details": (),
                    "reason": ""
                }),
                "disapprovalReasons": (json!({})),
                "status": ""
            })
        ),
        "vendorIds": (),
        "version": 0,
        "video": json!({
            "videoUrl": "",
            "videoVastXml": ""
        })
    });

    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}}/v2beta1/accounts/:accountId/creatives/:creativeId \
  --header 'content-type: application/json' \
  --data '{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}'
echo '{
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": {
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  },
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    {
      "contexts": [
        {
          "all": "",
          "appType": {
            "appTypes": []
          },
          "auctionType": {
            "auctionTypes": []
          },
          "location": {
            "geoCriteriaIds": []
          },
          "platform": {
            "platforms": []
          },
          "securityType": {
            "securities": []
          }
        }
      ],
      "details": [],
      "type": ""
    }
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": {
    "height": 0,
    "snippet": "",
    "width": 0
  },
  "impressionTrackingUrls": [],
  "native": {
    "advertiserName": "",
    "appIcon": {
      "height": 0,
      "url": "",
      "width": 0
    },
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": {},
    "logo": {},
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  },
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    {
      "contexts": [
        {}
      ],
      "disapproval": {
        "details": [],
        "reason": ""
      },
      "disapprovalReasons": [
        {}
      ],
      "status": ""
    }
  ],
  "vendorIds": [],
  "version": 0,
  "video": {
    "videoUrl": "",
    "videoVastXml": ""
  }
}' |  \
  http PUT {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "accountId": "",\n  "adChoicesDestinationUrl": "",\n  "adTechnologyProviders": {\n    "detectedProviderIds": [],\n    "hasUnidentifiedProvider": false\n  },\n  "advertiserName": "",\n  "agencyId": "",\n  "apiUpdateTime": "",\n  "attributes": [],\n  "clickThroughUrls": [],\n  "corrections": [\n    {\n      "contexts": [\n        {\n          "all": "",\n          "appType": {\n            "appTypes": []\n          },\n          "auctionType": {\n            "auctionTypes": []\n          },\n          "location": {\n            "geoCriteriaIds": []\n          },\n          "platform": {\n            "platforms": []\n          },\n          "securityType": {\n            "securities": []\n          }\n        }\n      ],\n      "details": [],\n      "type": ""\n    }\n  ],\n  "creativeId": "",\n  "dealsStatus": "",\n  "declaredClickThroughUrls": [],\n  "detectedAdvertiserIds": [],\n  "detectedDomains": [],\n  "detectedLanguages": [],\n  "detectedProductCategories": [],\n  "detectedSensitiveCategories": [],\n  "html": {\n    "height": 0,\n    "snippet": "",\n    "width": 0\n  },\n  "impressionTrackingUrls": [],\n  "native": {\n    "advertiserName": "",\n    "appIcon": {\n      "height": 0,\n      "url": "",\n      "width": 0\n    },\n    "body": "",\n    "callToAction": "",\n    "clickLinkUrl": "",\n    "clickTrackingUrl": "",\n    "headline": "",\n    "image": {},\n    "logo": {},\n    "priceDisplayText": "",\n    "starRating": "",\n    "storeUrl": "",\n    "videoUrl": ""\n  },\n  "openAuctionStatus": "",\n  "restrictedCategories": [],\n  "servingRestrictions": [\n    {\n      "contexts": [\n        {}\n      ],\n      "disapproval": {\n        "details": [],\n        "reason": ""\n      },\n      "disapprovalReasons": [\n        {}\n      ],\n      "status": ""\n    }\n  ],\n  "vendorIds": [],\n  "version": 0,\n  "video": {\n    "videoUrl": "",\n    "videoVastXml": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "accountId": "",
  "adChoicesDestinationUrl": "",
  "adTechnologyProviders": [
    "detectedProviderIds": [],
    "hasUnidentifiedProvider": false
  ],
  "advertiserName": "",
  "agencyId": "",
  "apiUpdateTime": "",
  "attributes": [],
  "clickThroughUrls": [],
  "corrections": [
    [
      "contexts": [
        [
          "all": "",
          "appType": ["appTypes": []],
          "auctionType": ["auctionTypes": []],
          "location": ["geoCriteriaIds": []],
          "platform": ["platforms": []],
          "securityType": ["securities": []]
        ]
      ],
      "details": [],
      "type": ""
    ]
  ],
  "creativeId": "",
  "dealsStatus": "",
  "declaredClickThroughUrls": [],
  "detectedAdvertiserIds": [],
  "detectedDomains": [],
  "detectedLanguages": [],
  "detectedProductCategories": [],
  "detectedSensitiveCategories": [],
  "html": [
    "height": 0,
    "snippet": "",
    "width": 0
  ],
  "impressionTrackingUrls": [],
  "native": [
    "advertiserName": "",
    "appIcon": [
      "height": 0,
      "url": "",
      "width": 0
    ],
    "body": "",
    "callToAction": "",
    "clickLinkUrl": "",
    "clickTrackingUrl": "",
    "headline": "",
    "image": [],
    "logo": [],
    "priceDisplayText": "",
    "starRating": "",
    "storeUrl": "",
    "videoUrl": ""
  ],
  "openAuctionStatus": "",
  "restrictedCategories": [],
  "servingRestrictions": [
    [
      "contexts": [[]],
      "disapproval": [
        "details": [],
        "reason": ""
      ],
      "disapprovalReasons": [[]],
      "status": ""
    ]
  ],
  "vendorIds": [],
  "version": 0,
  "video": [
    "videoUrl": "",
    "videoVastXml": ""
  ]
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId")! 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 adexchangebuyer2.accounts.creatives.watch
{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch
QUERY PARAMS

accountId
creativeId
BODY json

{
  "topic": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch");

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  \"topic\": \"\"\n}");

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

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch" {:content-type :json
                                                                                                    :form-params {:topic ""}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"topic\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch"),
    Content = new StringContent("{\n  \"topic\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"topic\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch"

	payload := strings.NewReader("{\n  \"topic\": \"\"\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/v2beta1/accounts/:accountId/creatives/:creativeId:watch HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 17

{
  "topic": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"topic\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"topic\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"topic\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch")
  .header("content-type", "application/json")
  .body("{\n  \"topic\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  topic: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch',
  headers: {'content-type': 'application/json'},
  data: {topic: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"topic":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "topic": ""\n}'
};

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch',
  headers: {'content-type': 'application/json'},
  body: {topic: ''},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch');

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch',
  headers: {'content-type': 'application/json'},
  data: {topic: ''}
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"topic":""}'
};

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 = @{ @"topic": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"topic\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'topic' => ''
  ]),
  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}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch', [
  'body' => '{
  "topic": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch');
$request->setMethod(HTTP_METH_POST);

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

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

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

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

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

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

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

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId:watch", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch"

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

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch"

payload <- "{\n  \"topic\": \"\"\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}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch")

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  \"topic\": \"\"\n}"

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

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

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/creatives/:creativeId:watch') do |req|
  req.body = "{\n  \"topic\": \"\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch";

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

    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}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch \
  --header 'content-type: application/json' \
  --data '{
  "topic": ""
}'
echo '{
  "topic": ""
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "topic": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/creatives/:creativeId:watch
import Foundation

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

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

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

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

dataTask.resume()
GET adexchangebuyer2.accounts.finalizedProposals.list
{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals
QUERY PARAMS

accountId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals"

	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/v2beta1/accounts/:accountId/finalizedProposals HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/finalizedProposals',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals';
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}}/v2beta1/accounts/:accountId/finalizedProposals"]
                                                       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}}/v2beta1/accounts/:accountId/finalizedProposals" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/finalizedProposals")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals")

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/v2beta1/accounts/:accountId/finalizedProposals') do |req|
end

puts response.status
puts response.body
use reqwest;

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

    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}}/v2beta1/accounts/:accountId/finalizedProposals
http GET {{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals")! 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 adexchangebuyer2.accounts.finalizedProposals.pause
{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause
QUERY PARAMS

accountId
proposalId
BODY json

{
  "externalDealIds": [],
  "reason": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause");

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

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

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause" {:content-type :json
                                                                                                             :form-params {:externalDealIds []
                                                                                                                           :reason ""}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause"),
    Content = new StringContent("{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause"

	payload := strings.NewReader("{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}")

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

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

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

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

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

}
POST /baseUrl/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 43

{
  "externalDealIds": [],
  "reason": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause")
  .header("content-type", "application/json")
  .body("{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  externalDealIds: [],
  reason: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause',
  headers: {'content-type': 'application/json'},
  data: {externalDealIds: [], reason: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"externalDealIds":[],"reason":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "externalDealIds": [],\n  "reason": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause")
  .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/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause',
  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({externalDealIds: [], reason: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause',
  headers: {'content-type': 'application/json'},
  body: {externalDealIds: [], reason: ''},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause');

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

req.type('json');
req.send({
  externalDealIds: [],
  reason: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause',
  headers: {'content-type': 'application/json'},
  data: {externalDealIds: [], reason: ''}
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"externalDealIds":[],"reason":""}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"externalDealIds": @[  ],
                              @"reason": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'externalDealIds' => [
        
    ],
    'reason' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause', [
  'body' => '{
  "externalDealIds": [],
  "reason": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause');
$request->setMethod(HTTP_METH_POST);

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

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

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

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

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

payload = "{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause"

payload = {
    "externalDealIds": [],
    "reason": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause"

payload <- "{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause")

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  \"externalDealIds\": [],\n  \"reason\": \"\"\n}"

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

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

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause') do |req|
  req.body = "{\n  \"externalDealIds\": [],\n  \"reason\": \"\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause";

    let payload = json!({
        "externalDealIds": (),
        "reason": ""
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause \
  --header 'content-type: application/json' \
  --data '{
  "externalDealIds": [],
  "reason": ""
}'
echo '{
  "externalDealIds": [],
  "reason": ""
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "externalDealIds": [],\n  "reason": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:pause
import Foundation

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

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

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

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

dataTask.resume()
POST adexchangebuyer2.accounts.finalizedProposals.resume
{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume
QUERY PARAMS

accountId
proposalId
BODY json

{
  "externalDealIds": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume");

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

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

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume" {:content-type :json
                                                                                                              :form-params {:externalDealIds []}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"externalDealIds\": []\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume"),
    Content = new StringContent("{\n  \"externalDealIds\": []\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"externalDealIds\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume"

	payload := strings.NewReader("{\n  \"externalDealIds\": []\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/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 27

{
  "externalDealIds": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"externalDealIds\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"externalDealIds\": []\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"externalDealIds\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume")
  .header("content-type", "application/json")
  .body("{\n  \"externalDealIds\": []\n}")
  .asString();
const data = JSON.stringify({
  externalDealIds: []
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume',
  headers: {'content-type': 'application/json'},
  data: {externalDealIds: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"externalDealIds":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "externalDealIds": []\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"externalDealIds\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume")
  .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/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume',
  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({externalDealIds: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume',
  headers: {'content-type': 'application/json'},
  body: {externalDealIds: []},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume');

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume',
  headers: {'content-type': 'application/json'},
  data: {externalDealIds: []}
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"externalDealIds":[]}'
};

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

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"externalDealIds\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'externalDealIds' => [
        
    ]
  ]),
  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}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume', [
  'body' => '{
  "externalDealIds": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume');
$request->setMethod(HTTP_METH_POST);

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

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

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

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

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

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

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

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume"

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

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume"

payload <- "{\n  \"externalDealIds\": []\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}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume")

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  \"externalDealIds\": []\n}"

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

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

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume') do |req|
  req.body = "{\n  \"externalDealIds\": []\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume";

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

    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}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume \
  --header 'content-type: application/json' \
  --data '{
  "externalDealIds": []
}'
echo '{
  "externalDealIds": []
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "externalDealIds": []\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/finalizedProposals/:proposalId:resume
import Foundation

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

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

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

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

dataTask.resume()
GET adexchangebuyer2.accounts.products.get
{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId
QUERY PARAMS

accountId
productId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId"

	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/v2beta1/accounts/:accountId/products/:productId HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/products/:productId',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId';
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}}/v2beta1/accounts/:accountId/products/:productId"]
                                                       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}}/v2beta1/accounts/:accountId/products/:productId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/products/:productId")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId")

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/v2beta1/accounts/:accountId/products/:productId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId";

    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}}/v2beta1/accounts/:accountId/products/:productId
http GET {{baseUrl}}/v2beta1/accounts/:accountId/products/:productId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/products/:productId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/products/:productId")! 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 adexchangebuyer2.accounts.products.list
{{baseUrl}}/v2beta1/accounts/:accountId/products
QUERY PARAMS

accountId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/products");

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

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/products")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/products"

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

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/products"

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

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

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

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

}
GET /baseUrl/v2beta1/accounts/:accountId/products HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/products")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/products")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/products');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/products'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/products';
const options = {method: 'GET'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/products")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/products',
  headers: {}
};

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/products'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/products');

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/products'
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/products';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/products"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/products" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/products');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/products');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/products")

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/products"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/products"

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

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

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/products")

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

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

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

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

response = conn.get('/baseUrl/v2beta1/accounts/:accountId/products') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v2beta1/accounts/:accountId/products
http GET {{baseUrl}}/v2beta1/accounts/:accountId/products
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/products
import Foundation

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

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

dataTask.resume()
POST adexchangebuyer2.accounts.proposals.accept
{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept
QUERY PARAMS

accountId
proposalId
BODY json

{
  "proposalRevision": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept");

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  \"proposalRevision\": \"\"\n}");

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

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept" {:content-type :json
                                                                                                     :form-params {:proposalRevision ""}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"proposalRevision\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept"),
    Content = new StringContent("{\n  \"proposalRevision\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"proposalRevision\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept"

	payload := strings.NewReader("{\n  \"proposalRevision\": \"\"\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/v2beta1/accounts/:accountId/proposals/:proposalId:accept HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 28

{
  "proposalRevision": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"proposalRevision\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"proposalRevision\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"proposalRevision\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept")
  .header("content-type", "application/json")
  .body("{\n  \"proposalRevision\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  proposalRevision: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept',
  headers: {'content-type': 'application/json'},
  data: {proposalRevision: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"proposalRevision":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "proposalRevision": ""\n}'
};

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept',
  headers: {'content-type': 'application/json'},
  body: {proposalRevision: ''},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept');

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept',
  headers: {'content-type': 'application/json'},
  data: {proposalRevision: ''}
};

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

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"proposalRevision":""}'
};

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 = @{ @"proposalRevision": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"proposalRevision\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'proposalRevision' => ''
  ]),
  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}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept', [
  'body' => '{
  "proposalRevision": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept');
$request->setMethod(HTTP_METH_POST);

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

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

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

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

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

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

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

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:accept", payload, headers)

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

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

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept"

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

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

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

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept"

payload <- "{\n  \"proposalRevision\": \"\"\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}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept")

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  \"proposalRevision\": \"\"\n}"

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

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

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:accept') do |req|
  req.body = "{\n  \"proposalRevision\": \"\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept";

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

    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}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept \
  --header 'content-type: application/json' \
  --data '{
  "proposalRevision": ""
}'
echo '{
  "proposalRevision": ""
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "proposalRevision": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:accept
import Foundation

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

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

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

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

dataTask.resume()
POST adexchangebuyer2.accounts.proposals.addNote
{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote
QUERY PARAMS

accountId
proposalId
BODY json

{
  "note": {
    "createTime": "",
    "creatorRole": "",
    "note": "",
    "noteId": "",
    "proposalRevision": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote");

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  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}");

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

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote" {:content-type :json
                                                                                                      :form-params {:note {:createTime ""
                                                                                                                           :creatorRole ""
                                                                                                                           :note ""
                                                                                                                           :noteId ""
                                                                                                                           :proposalRevision ""}}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote"),
    Content = new StringContent("{\n  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\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}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote"

	payload := strings.NewReader("{\n  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:addNote HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 125

{
  "note": {
    "createTime": "",
    "creatorRole": "",
    "note": "",
    "noteId": "",
    "proposalRevision": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\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  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote")
  .header("content-type", "application/json")
  .body("{\n  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  note: {
    createTime: '',
    creatorRole: '',
    note: '',
    noteId: '',
    proposalRevision: ''
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote',
  headers: {'content-type': 'application/json'},
  data: {
    note: {createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"note":{"createTime":"","creatorRole":"","note":"","noteId":"","proposalRevision":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "note": {\n    "createTime": "",\n    "creatorRole": "",\n    "note": "",\n    "noteId": "",\n    "proposalRevision": ""\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  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote")
  .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/v2beta1/accounts/:accountId/proposals/:proposalId:addNote',
  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({
  note: {createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote',
  headers: {'content-type': 'application/json'},
  body: {
    note: {createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote');

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

req.type('json');
req.send({
  note: {
    createTime: '',
    creatorRole: '',
    note: '',
    noteId: '',
    proposalRevision: ''
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote',
  headers: {'content-type': 'application/json'},
  data: {
    note: {createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"note":{"createTime":"","creatorRole":"","note":"","noteId":"","proposalRevision":""}}'
};

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 = @{ @"note": @{ @"createTime": @"", @"creatorRole": @"", @"note": @"", @"noteId": @"", @"proposalRevision": @"" } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'note' => [
        'createTime' => '',
        'creatorRole' => '',
        'note' => '',
        'noteId' => '',
        'proposalRevision' => ''
    ]
  ]),
  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}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote', [
  'body' => '{
  "note": {
    "createTime": "",
    "creatorRole": "",
    "note": "",
    "noteId": "",
    "proposalRevision": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'note' => [
    'createTime' => '',
    'creatorRole' => '',
    'note' => '',
    'noteId' => '',
    'proposalRevision' => ''
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'note' => [
    'createTime' => '',
    'creatorRole' => '',
    'note' => '',
    'noteId' => '',
    'proposalRevision' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote');
$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}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "note": {
    "createTime": "",
    "creatorRole": "",
    "note": "",
    "noteId": "",
    "proposalRevision": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "note": {
    "createTime": "",
    "creatorRole": "",
    "note": "",
    "noteId": "",
    "proposalRevision": ""
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:addNote", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote"

payload = { "note": {
        "createTime": "",
        "creatorRole": "",
        "note": "",
        "noteId": "",
        "proposalRevision": ""
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote"

payload <- "{\n  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote")

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  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:addNote') do |req|
  req.body = "{\n  \"note\": {\n    \"createTime\": \"\",\n    \"creatorRole\": \"\",\n    \"note\": \"\",\n    \"noteId\": \"\",\n    \"proposalRevision\": \"\"\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote";

    let payload = json!({"note": json!({
            "createTime": "",
            "creatorRole": "",
            "note": "",
            "noteId": "",
            "proposalRevision": ""
        })});

    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}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote \
  --header 'content-type: application/json' \
  --data '{
  "note": {
    "createTime": "",
    "creatorRole": "",
    "note": "",
    "noteId": "",
    "proposalRevision": ""
  }
}'
echo '{
  "note": {
    "createTime": "",
    "creatorRole": "",
    "note": "",
    "noteId": "",
    "proposalRevision": ""
  }
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "note": {\n    "createTime": "",\n    "creatorRole": "",\n    "note": "",\n    "noteId": "",\n    "proposalRevision": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["note": [
    "createTime": "",
    "creatorRole": "",
    "note": "",
    "noteId": "",
    "proposalRevision": ""
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:addNote")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST adexchangebuyer2.accounts.proposals.cancelNegotiation
{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation
QUERY PARAMS

accountId
proposalId
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation");

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, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation"),
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation"

	payload := strings.NewReader("{}")

	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/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation")
  .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/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation',
  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({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation',
  headers: {'content-type': 'application/json'},
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation');
$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}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation"

payload = {}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation"

payload <- "{}"

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}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation")

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 = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation') do |req|
  req.body = "{}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation";

    let payload = 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}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:cancelNegotiation")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST adexchangebuyer2.accounts.proposals.completeSetup
{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup
QUERY PARAMS

accountId
proposalId
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup");

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, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup"),
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup"

	payload := strings.NewReader("{}")

	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/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup")
  .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/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup',
  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({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup',
  headers: {'content-type': 'application/json'},
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup');
$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}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup"

payload = {}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup"

payload <- "{}"

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}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup")

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 = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup') do |req|
  req.body = "{}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup";

    let payload = 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}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:completeSetup")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST adexchangebuyer2.accounts.proposals.create
{{baseUrl}}/v2beta1/accounts/:accountId/proposals
QUERY PARAMS

accountId
BODY json

{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/proposals");

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  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/proposals" {:content-type :json
                                                                                  :form-params {:billedBuyer {:accountId ""}
                                                                                                :buyer {}
                                                                                                :buyerContacts [{:email ""
                                                                                                                 :name ""}]
                                                                                                :buyerPrivateData {:referenceId ""}
                                                                                                :deals [{:availableEndTime ""
                                                                                                         :availableStartTime ""
                                                                                                         :buyerPrivateData {}
                                                                                                         :createProductId ""
                                                                                                         :createProductRevision ""
                                                                                                         :createTime ""
                                                                                                         :creativePreApprovalPolicy ""
                                                                                                         :creativeRestrictions {:creativeFormat ""
                                                                                                                                :creativeSpecifications [{:creativeCompanionSizes [{:height ""
                                                                                                                                                                                    :sizeType ""
                                                                                                                                                                                    :width ""}]
                                                                                                                                                          :creativeSize {}}]
                                                                                                                                :skippableAdType ""}
                                                                                                         :creativeSafeFrameCompatibility ""
                                                                                                         :dealId ""
                                                                                                         :dealServingMetadata {:dealPauseStatus {:buyerPauseReason ""
                                                                                                                                                 :firstPausedBy ""
                                                                                                                                                 :hasBuyerPaused false
                                                                                                                                                 :hasSellerPaused false
                                                                                                                                                 :sellerPauseReason ""}}
                                                                                                         :dealTerms {:brandingType ""
                                                                                                                     :description ""
                                                                                                                     :estimatedGrossSpend {:amount {:currencyCode ""
                                                                                                                                                    :nanos 0
                                                                                                                                                    :units ""}
                                                                                                                                           :pricingType ""}
                                                                                                                     :estimatedImpressionsPerDay ""
                                                                                                                     :guaranteedFixedPriceTerms {:fixedPrices [{:advertiserIds []
                                                                                                                                                                :buyer {}
                                                                                                                                                                :price {}}]
                                                                                                                                                 :guaranteedImpressions ""
                                                                                                                                                 :guaranteedLooks ""
                                                                                                                                                 :impressionCap ""
                                                                                                                                                 :minimumDailyLooks ""
                                                                                                                                                 :percentShareOfVoice ""
                                                                                                                                                 :reservationType ""}
                                                                                                                     :nonGuaranteedAuctionTerms {:autoOptimizePrivateAuction false
                                                                                                                                                 :reservePricesPerBuyer [{}]}
                                                                                                                     :nonGuaranteedFixedPriceTerms {:fixedPrices [{}]}
                                                                                                                     :sellerTimeZone ""}
                                                                                                         :deliveryControl {:creativeBlockingLevel ""
                                                                                                                           :deliveryRateType ""
                                                                                                                           :frequencyCaps [{:maxImpressions 0
                                                                                                                                            :numTimeUnits 0
                                                                                                                                            :timeUnitType ""}]}
                                                                                                         :description ""
                                                                                                         :displayName ""
                                                                                                         :externalDealId ""
                                                                                                         :isSetupComplete false
                                                                                                         :programmaticCreativeSource ""
                                                                                                         :proposalId ""
                                                                                                         :sellerContacts [{}]
                                                                                                         :syndicationProduct ""
                                                                                                         :targeting {:geoTargeting {:excludedCriteriaIds []
                                                                                                                                    :targetedCriteriaIds []}
                                                                                                                     :inventorySizeTargeting {:excludedInventorySizes [{}]
                                                                                                                                              :targetedInventorySizes [{}]}
                                                                                                                     :placementTargeting {:mobileApplicationTargeting {:firstPartyTargeting {:excludedAppIds []
                                                                                                                                                                                             :targetedAppIds []}}
                                                                                                                                          :urlTargeting {:excludedUrls []
                                                                                                                                                         :targetedUrls []}}
                                                                                                                     :technologyTargeting {:deviceCapabilityTargeting {}
                                                                                                                                           :deviceCategoryTargeting {}
                                                                                                                                           :operatingSystemTargeting {:operatingSystemCriteria {}
                                                                                                                                                                      :operatingSystemVersionCriteria {}}}
                                                                                                                     :videoTargeting {:excludedPositionTypes []
                                                                                                                                      :targetedPositionTypes []}}
                                                                                                         :targetingCriterion [{:exclusions [{:creativeSizeValue {:allowedFormats []
                                                                                                                                                                 :companionSizes [{:height 0
                                                                                                                                                                                   :width 0}]
                                                                                                                                                                 :creativeSizeType ""
                                                                                                                                                                 :nativeTemplate ""
                                                                                                                                                                 :size {}
                                                                                                                                                                 :skippableAdType ""}
                                                                                                                                             :dayPartTargetingValue {:dayParts [{:dayOfWeek ""
                                                                                                                                                                                 :endTime {:hours 0
                                                                                                                                                                                           :minutes 0
                                                                                                                                                                                           :nanos 0
                                                                                                                                                                                           :seconds 0}
                                                                                                                                                                                 :startTime {}}]
                                                                                                                                                                     :timeZoneType ""}
                                                                                                                                             :longValue ""
                                                                                                                                             :stringValue ""}]
                                                                                                                               :inclusions [{}]
                                                                                                                               :key ""}]
                                                                                                         :updateTime ""
                                                                                                         :webPropertyCode ""}]
                                                                                                :displayName ""
                                                                                                :isRenegotiating false
                                                                                                :isSetupComplete false
                                                                                                :lastUpdaterOrCommentorRole ""
                                                                                                :notes [{:createTime ""
                                                                                                         :creatorRole ""
                                                                                                         :note ""
                                                                                                         :noteId ""
                                                                                                         :proposalRevision ""}]
                                                                                                :originatorRole ""
                                                                                                :privateAuctionId ""
                                                                                                :proposalId ""
                                                                                                :proposalRevision ""
                                                                                                :proposalState ""
                                                                                                :seller {:accountId ""
                                                                                                         :subAccountId ""}
                                                                                                :sellerContacts [{}]
                                                                                                :termsAndConditions ""
                                                                                                :updateTime ""}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/proposals"),
    Content = new StringContent("{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/proposals");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/proposals"

	payload := strings.NewReader("{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\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/v2beta1/accounts/:accountId/proposals HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 5376

{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/proposals")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/proposals"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/proposals")
  .header("content-type", "application/json")
  .body("{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  billedBuyer: {
    accountId: ''
  },
  buyer: {},
  buyerContacts: [
    {
      email: '',
      name: ''
    }
  ],
  buyerPrivateData: {
    referenceId: ''
  },
  deals: [
    {
      availableEndTime: '',
      availableStartTime: '',
      buyerPrivateData: {},
      createProductId: '',
      createProductRevision: '',
      createTime: '',
      creativePreApprovalPolicy: '',
      creativeRestrictions: {
        creativeFormat: '',
        creativeSpecifications: [
          {
            creativeCompanionSizes: [
              {
                height: '',
                sizeType: '',
                width: ''
              }
            ],
            creativeSize: {}
          }
        ],
        skippableAdType: ''
      },
      creativeSafeFrameCompatibility: '',
      dealId: '',
      dealServingMetadata: {
        dealPauseStatus: {
          buyerPauseReason: '',
          firstPausedBy: '',
          hasBuyerPaused: false,
          hasSellerPaused: false,
          sellerPauseReason: ''
        }
      },
      dealTerms: {
        brandingType: '',
        description: '',
        estimatedGrossSpend: {
          amount: {
            currencyCode: '',
            nanos: 0,
            units: ''
          },
          pricingType: ''
        },
        estimatedImpressionsPerDay: '',
        guaranteedFixedPriceTerms: {
          fixedPrices: [
            {
              advertiserIds: [],
              buyer: {},
              price: {}
            }
          ],
          guaranteedImpressions: '',
          guaranteedLooks: '',
          impressionCap: '',
          minimumDailyLooks: '',
          percentShareOfVoice: '',
          reservationType: ''
        },
        nonGuaranteedAuctionTerms: {
          autoOptimizePrivateAuction: false,
          reservePricesPerBuyer: [
            {}
          ]
        },
        nonGuaranteedFixedPriceTerms: {
          fixedPrices: [
            {}
          ]
        },
        sellerTimeZone: ''
      },
      deliveryControl: {
        creativeBlockingLevel: '',
        deliveryRateType: '',
        frequencyCaps: [
          {
            maxImpressions: 0,
            numTimeUnits: 0,
            timeUnitType: ''
          }
        ]
      },
      description: '',
      displayName: '',
      externalDealId: '',
      isSetupComplete: false,
      programmaticCreativeSource: '',
      proposalId: '',
      sellerContacts: [
        {}
      ],
      syndicationProduct: '',
      targeting: {
        geoTargeting: {
          excludedCriteriaIds: [],
          targetedCriteriaIds: []
        },
        inventorySizeTargeting: {
          excludedInventorySizes: [
            {}
          ],
          targetedInventorySizes: [
            {}
          ]
        },
        placementTargeting: {
          mobileApplicationTargeting: {
            firstPartyTargeting: {
              excludedAppIds: [],
              targetedAppIds: []
            }
          },
          urlTargeting: {
            excludedUrls: [],
            targetedUrls: []
          }
        },
        technologyTargeting: {
          deviceCapabilityTargeting: {},
          deviceCategoryTargeting: {},
          operatingSystemTargeting: {
            operatingSystemCriteria: {},
            operatingSystemVersionCriteria: {}
          }
        },
        videoTargeting: {
          excludedPositionTypes: [],
          targetedPositionTypes: []
        }
      },
      targetingCriterion: [
        {
          exclusions: [
            {
              creativeSizeValue: {
                allowedFormats: [],
                companionSizes: [
                  {
                    height: 0,
                    width: 0
                  }
                ],
                creativeSizeType: '',
                nativeTemplate: '',
                size: {},
                skippableAdType: ''
              },
              dayPartTargetingValue: {
                dayParts: [
                  {
                    dayOfWeek: '',
                    endTime: {
                      hours: 0,
                      minutes: 0,
                      nanos: 0,
                      seconds: 0
                    },
                    startTime: {}
                  }
                ],
                timeZoneType: ''
              },
              longValue: '',
              stringValue: ''
            }
          ],
          inclusions: [
            {}
          ],
          key: ''
        }
      ],
      updateTime: '',
      webPropertyCode: ''
    }
  ],
  displayName: '',
  isRenegotiating: false,
  isSetupComplete: false,
  lastUpdaterOrCommentorRole: '',
  notes: [
    {
      createTime: '',
      creatorRole: '',
      note: '',
      noteId: '',
      proposalRevision: ''
    }
  ],
  originatorRole: '',
  privateAuctionId: '',
  proposalId: '',
  proposalRevision: '',
  proposalState: '',
  seller: {
    accountId: '',
    subAccountId: ''
  },
  sellerContacts: [
    {}
  ],
  termsAndConditions: '',
  updateTime: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals',
  headers: {'content-type': 'application/json'},
  data: {
    billedBuyer: {accountId: ''},
    buyer: {},
    buyerContacts: [{email: '', name: ''}],
    buyerPrivateData: {referenceId: ''},
    deals: [
      {
        availableEndTime: '',
        availableStartTime: '',
        buyerPrivateData: {},
        createProductId: '',
        createProductRevision: '',
        createTime: '',
        creativePreApprovalPolicy: '',
        creativeRestrictions: {
          creativeFormat: '',
          creativeSpecifications: [
            {
              creativeCompanionSizes: [{height: '', sizeType: '', width: ''}],
              creativeSize: {}
            }
          ],
          skippableAdType: ''
        },
        creativeSafeFrameCompatibility: '',
        dealId: '',
        dealServingMetadata: {
          dealPauseStatus: {
            buyerPauseReason: '',
            firstPausedBy: '',
            hasBuyerPaused: false,
            hasSellerPaused: false,
            sellerPauseReason: ''
          }
        },
        dealTerms: {
          brandingType: '',
          description: '',
          estimatedGrossSpend: {amount: {currencyCode: '', nanos: 0, units: ''}, pricingType: ''},
          estimatedImpressionsPerDay: '',
          guaranteedFixedPriceTerms: {
            fixedPrices: [{advertiserIds: [], buyer: {}, price: {}}],
            guaranteedImpressions: '',
            guaranteedLooks: '',
            impressionCap: '',
            minimumDailyLooks: '',
            percentShareOfVoice: '',
            reservationType: ''
          },
          nonGuaranteedAuctionTerms: {autoOptimizePrivateAuction: false, reservePricesPerBuyer: [{}]},
          nonGuaranteedFixedPriceTerms: {fixedPrices: [{}]},
          sellerTimeZone: ''
        },
        deliveryControl: {
          creativeBlockingLevel: '',
          deliveryRateType: '',
          frequencyCaps: [{maxImpressions: 0, numTimeUnits: 0, timeUnitType: ''}]
        },
        description: '',
        displayName: '',
        externalDealId: '',
        isSetupComplete: false,
        programmaticCreativeSource: '',
        proposalId: '',
        sellerContacts: [{}],
        syndicationProduct: '',
        targeting: {
          geoTargeting: {excludedCriteriaIds: [], targetedCriteriaIds: []},
          inventorySizeTargeting: {excludedInventorySizes: [{}], targetedInventorySizes: [{}]},
          placementTargeting: {
            mobileApplicationTargeting: {firstPartyTargeting: {excludedAppIds: [], targetedAppIds: []}},
            urlTargeting: {excludedUrls: [], targetedUrls: []}
          },
          technologyTargeting: {
            deviceCapabilityTargeting: {},
            deviceCategoryTargeting: {},
            operatingSystemTargeting: {operatingSystemCriteria: {}, operatingSystemVersionCriteria: {}}
          },
          videoTargeting: {excludedPositionTypes: [], targetedPositionTypes: []}
        },
        targetingCriterion: [
          {
            exclusions: [
              {
                creativeSizeValue: {
                  allowedFormats: [],
                  companionSizes: [{height: 0, width: 0}],
                  creativeSizeType: '',
                  nativeTemplate: '',
                  size: {},
                  skippableAdType: ''
                },
                dayPartTargetingValue: {
                  dayParts: [
                    {
                      dayOfWeek: '',
                      endTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
                      startTime: {}
                    }
                  ],
                  timeZoneType: ''
                },
                longValue: '',
                stringValue: ''
              }
            ],
            inclusions: [{}],
            key: ''
          }
        ],
        updateTime: '',
        webPropertyCode: ''
      }
    ],
    displayName: '',
    isRenegotiating: false,
    isSetupComplete: false,
    lastUpdaterOrCommentorRole: '',
    notes: [{createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}],
    originatorRole: '',
    privateAuctionId: '',
    proposalId: '',
    proposalRevision: '',
    proposalState: '',
    seller: {accountId: '', subAccountId: ''},
    sellerContacts: [{}],
    termsAndConditions: '',
    updateTime: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billedBuyer":{"accountId":""},"buyer":{},"buyerContacts":[{"email":"","name":""}],"buyerPrivateData":{"referenceId":""},"deals":[{"availableEndTime":"","availableStartTime":"","buyerPrivateData":{},"createProductId":"","createProductRevision":"","createTime":"","creativePreApprovalPolicy":"","creativeRestrictions":{"creativeFormat":"","creativeSpecifications":[{"creativeCompanionSizes":[{"height":"","sizeType":"","width":""}],"creativeSize":{}}],"skippableAdType":""},"creativeSafeFrameCompatibility":"","dealId":"","dealServingMetadata":{"dealPauseStatus":{"buyerPauseReason":"","firstPausedBy":"","hasBuyerPaused":false,"hasSellerPaused":false,"sellerPauseReason":""}},"dealTerms":{"brandingType":"","description":"","estimatedGrossSpend":{"amount":{"currencyCode":"","nanos":0,"units":""},"pricingType":""},"estimatedImpressionsPerDay":"","guaranteedFixedPriceTerms":{"fixedPrices":[{"advertiserIds":[],"buyer":{},"price":{}}],"guaranteedImpressions":"","guaranteedLooks":"","impressionCap":"","minimumDailyLooks":"","percentShareOfVoice":"","reservationType":""},"nonGuaranteedAuctionTerms":{"autoOptimizePrivateAuction":false,"reservePricesPerBuyer":[{}]},"nonGuaranteedFixedPriceTerms":{"fixedPrices":[{}]},"sellerTimeZone":""},"deliveryControl":{"creativeBlockingLevel":"","deliveryRateType":"","frequencyCaps":[{"maxImpressions":0,"numTimeUnits":0,"timeUnitType":""}]},"description":"","displayName":"","externalDealId":"","isSetupComplete":false,"programmaticCreativeSource":"","proposalId":"","sellerContacts":[{}],"syndicationProduct":"","targeting":{"geoTargeting":{"excludedCriteriaIds":[],"targetedCriteriaIds":[]},"inventorySizeTargeting":{"excludedInventorySizes":[{}],"targetedInventorySizes":[{}]},"placementTargeting":{"mobileApplicationTargeting":{"firstPartyTargeting":{"excludedAppIds":[],"targetedAppIds":[]}},"urlTargeting":{"excludedUrls":[],"targetedUrls":[]}},"technologyTargeting":{"deviceCapabilityTargeting":{},"deviceCategoryTargeting":{},"operatingSystemTargeting":{"operatingSystemCriteria":{},"operatingSystemVersionCriteria":{}}},"videoTargeting":{"excludedPositionTypes":[],"targetedPositionTypes":[]}},"targetingCriterion":[{"exclusions":[{"creativeSizeValue":{"allowedFormats":[],"companionSizes":[{"height":0,"width":0}],"creativeSizeType":"","nativeTemplate":"","size":{},"skippableAdType":""},"dayPartTargetingValue":{"dayParts":[{"dayOfWeek":"","endTime":{"hours":0,"minutes":0,"nanos":0,"seconds":0},"startTime":{}}],"timeZoneType":""},"longValue":"","stringValue":""}],"inclusions":[{}],"key":""}],"updateTime":"","webPropertyCode":""}],"displayName":"","isRenegotiating":false,"isSetupComplete":false,"lastUpdaterOrCommentorRole":"","notes":[{"createTime":"","creatorRole":"","note":"","noteId":"","proposalRevision":""}],"originatorRole":"","privateAuctionId":"","proposalId":"","proposalRevision":"","proposalState":"","seller":{"accountId":"","subAccountId":""},"sellerContacts":[{}],"termsAndConditions":"","updateTime":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "billedBuyer": {\n    "accountId": ""\n  },\n  "buyer": {},\n  "buyerContacts": [\n    {\n      "email": "",\n      "name": ""\n    }\n  ],\n  "buyerPrivateData": {\n    "referenceId": ""\n  },\n  "deals": [\n    {\n      "availableEndTime": "",\n      "availableStartTime": "",\n      "buyerPrivateData": {},\n      "createProductId": "",\n      "createProductRevision": "",\n      "createTime": "",\n      "creativePreApprovalPolicy": "",\n      "creativeRestrictions": {\n        "creativeFormat": "",\n        "creativeSpecifications": [\n          {\n            "creativeCompanionSizes": [\n              {\n                "height": "",\n                "sizeType": "",\n                "width": ""\n              }\n            ],\n            "creativeSize": {}\n          }\n        ],\n        "skippableAdType": ""\n      },\n      "creativeSafeFrameCompatibility": "",\n      "dealId": "",\n      "dealServingMetadata": {\n        "dealPauseStatus": {\n          "buyerPauseReason": "",\n          "firstPausedBy": "",\n          "hasBuyerPaused": false,\n          "hasSellerPaused": false,\n          "sellerPauseReason": ""\n        }\n      },\n      "dealTerms": {\n        "brandingType": "",\n        "description": "",\n        "estimatedGrossSpend": {\n          "amount": {\n            "currencyCode": "",\n            "nanos": 0,\n            "units": ""\n          },\n          "pricingType": ""\n        },\n        "estimatedImpressionsPerDay": "",\n        "guaranteedFixedPriceTerms": {\n          "fixedPrices": [\n            {\n              "advertiserIds": [],\n              "buyer": {},\n              "price": {}\n            }\n          ],\n          "guaranteedImpressions": "",\n          "guaranteedLooks": "",\n          "impressionCap": "",\n          "minimumDailyLooks": "",\n          "percentShareOfVoice": "",\n          "reservationType": ""\n        },\n        "nonGuaranteedAuctionTerms": {\n          "autoOptimizePrivateAuction": false,\n          "reservePricesPerBuyer": [\n            {}\n          ]\n        },\n        "nonGuaranteedFixedPriceTerms": {\n          "fixedPrices": [\n            {}\n          ]\n        },\n        "sellerTimeZone": ""\n      },\n      "deliveryControl": {\n        "creativeBlockingLevel": "",\n        "deliveryRateType": "",\n        "frequencyCaps": [\n          {\n            "maxImpressions": 0,\n            "numTimeUnits": 0,\n            "timeUnitType": ""\n          }\n        ]\n      },\n      "description": "",\n      "displayName": "",\n      "externalDealId": "",\n      "isSetupComplete": false,\n      "programmaticCreativeSource": "",\n      "proposalId": "",\n      "sellerContacts": [\n        {}\n      ],\n      "syndicationProduct": "",\n      "targeting": {\n        "geoTargeting": {\n          "excludedCriteriaIds": [],\n          "targetedCriteriaIds": []\n        },\n        "inventorySizeTargeting": {\n          "excludedInventorySizes": [\n            {}\n          ],\n          "targetedInventorySizes": [\n            {}\n          ]\n        },\n        "placementTargeting": {\n          "mobileApplicationTargeting": {\n            "firstPartyTargeting": {\n              "excludedAppIds": [],\n              "targetedAppIds": []\n            }\n          },\n          "urlTargeting": {\n            "excludedUrls": [],\n            "targetedUrls": []\n          }\n        },\n        "technologyTargeting": {\n          "deviceCapabilityTargeting": {},\n          "deviceCategoryTargeting": {},\n          "operatingSystemTargeting": {\n            "operatingSystemCriteria": {},\n            "operatingSystemVersionCriteria": {}\n          }\n        },\n        "videoTargeting": {\n          "excludedPositionTypes": [],\n          "targetedPositionTypes": []\n        }\n      },\n      "targetingCriterion": [\n        {\n          "exclusions": [\n            {\n              "creativeSizeValue": {\n                "allowedFormats": [],\n                "companionSizes": [\n                  {\n                    "height": 0,\n                    "width": 0\n                  }\n                ],\n                "creativeSizeType": "",\n                "nativeTemplate": "",\n                "size": {},\n                "skippableAdType": ""\n              },\n              "dayPartTargetingValue": {\n                "dayParts": [\n                  {\n                    "dayOfWeek": "",\n                    "endTime": {\n                      "hours": 0,\n                      "minutes": 0,\n                      "nanos": 0,\n                      "seconds": 0\n                    },\n                    "startTime": {}\n                  }\n                ],\n                "timeZoneType": ""\n              },\n              "longValue": "",\n              "stringValue": ""\n            }\n          ],\n          "inclusions": [\n            {}\n          ],\n          "key": ""\n        }\n      ],\n      "updateTime": "",\n      "webPropertyCode": ""\n    }\n  ],\n  "displayName": "",\n  "isRenegotiating": false,\n  "isSetupComplete": false,\n  "lastUpdaterOrCommentorRole": "",\n  "notes": [\n    {\n      "createTime": "",\n      "creatorRole": "",\n      "note": "",\n      "noteId": "",\n      "proposalRevision": ""\n    }\n  ],\n  "originatorRole": "",\n  "privateAuctionId": "",\n  "proposalId": "",\n  "proposalRevision": "",\n  "proposalState": "",\n  "seller": {\n    "accountId": "",\n    "subAccountId": ""\n  },\n  "sellerContacts": [\n    {}\n  ],\n  "termsAndConditions": "",\n  "updateTime": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals")
  .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/v2beta1/accounts/:accountId/proposals',
  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({
  billedBuyer: {accountId: ''},
  buyer: {},
  buyerContacts: [{email: '', name: ''}],
  buyerPrivateData: {referenceId: ''},
  deals: [
    {
      availableEndTime: '',
      availableStartTime: '',
      buyerPrivateData: {},
      createProductId: '',
      createProductRevision: '',
      createTime: '',
      creativePreApprovalPolicy: '',
      creativeRestrictions: {
        creativeFormat: '',
        creativeSpecifications: [
          {
            creativeCompanionSizes: [{height: '', sizeType: '', width: ''}],
            creativeSize: {}
          }
        ],
        skippableAdType: ''
      },
      creativeSafeFrameCompatibility: '',
      dealId: '',
      dealServingMetadata: {
        dealPauseStatus: {
          buyerPauseReason: '',
          firstPausedBy: '',
          hasBuyerPaused: false,
          hasSellerPaused: false,
          sellerPauseReason: ''
        }
      },
      dealTerms: {
        brandingType: '',
        description: '',
        estimatedGrossSpend: {amount: {currencyCode: '', nanos: 0, units: ''}, pricingType: ''},
        estimatedImpressionsPerDay: '',
        guaranteedFixedPriceTerms: {
          fixedPrices: [{advertiserIds: [], buyer: {}, price: {}}],
          guaranteedImpressions: '',
          guaranteedLooks: '',
          impressionCap: '',
          minimumDailyLooks: '',
          percentShareOfVoice: '',
          reservationType: ''
        },
        nonGuaranteedAuctionTerms: {autoOptimizePrivateAuction: false, reservePricesPerBuyer: [{}]},
        nonGuaranteedFixedPriceTerms: {fixedPrices: [{}]},
        sellerTimeZone: ''
      },
      deliveryControl: {
        creativeBlockingLevel: '',
        deliveryRateType: '',
        frequencyCaps: [{maxImpressions: 0, numTimeUnits: 0, timeUnitType: ''}]
      },
      description: '',
      displayName: '',
      externalDealId: '',
      isSetupComplete: false,
      programmaticCreativeSource: '',
      proposalId: '',
      sellerContacts: [{}],
      syndicationProduct: '',
      targeting: {
        geoTargeting: {excludedCriteriaIds: [], targetedCriteriaIds: []},
        inventorySizeTargeting: {excludedInventorySizes: [{}], targetedInventorySizes: [{}]},
        placementTargeting: {
          mobileApplicationTargeting: {firstPartyTargeting: {excludedAppIds: [], targetedAppIds: []}},
          urlTargeting: {excludedUrls: [], targetedUrls: []}
        },
        technologyTargeting: {
          deviceCapabilityTargeting: {},
          deviceCategoryTargeting: {},
          operatingSystemTargeting: {operatingSystemCriteria: {}, operatingSystemVersionCriteria: {}}
        },
        videoTargeting: {excludedPositionTypes: [], targetedPositionTypes: []}
      },
      targetingCriterion: [
        {
          exclusions: [
            {
              creativeSizeValue: {
                allowedFormats: [],
                companionSizes: [{height: 0, width: 0}],
                creativeSizeType: '',
                nativeTemplate: '',
                size: {},
                skippableAdType: ''
              },
              dayPartTargetingValue: {
                dayParts: [
                  {
                    dayOfWeek: '',
                    endTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
                    startTime: {}
                  }
                ],
                timeZoneType: ''
              },
              longValue: '',
              stringValue: ''
            }
          ],
          inclusions: [{}],
          key: ''
        }
      ],
      updateTime: '',
      webPropertyCode: ''
    }
  ],
  displayName: '',
  isRenegotiating: false,
  isSetupComplete: false,
  lastUpdaterOrCommentorRole: '',
  notes: [{createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}],
  originatorRole: '',
  privateAuctionId: '',
  proposalId: '',
  proposalRevision: '',
  proposalState: '',
  seller: {accountId: '', subAccountId: ''},
  sellerContacts: [{}],
  termsAndConditions: '',
  updateTime: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals',
  headers: {'content-type': 'application/json'},
  body: {
    billedBuyer: {accountId: ''},
    buyer: {},
    buyerContacts: [{email: '', name: ''}],
    buyerPrivateData: {referenceId: ''},
    deals: [
      {
        availableEndTime: '',
        availableStartTime: '',
        buyerPrivateData: {},
        createProductId: '',
        createProductRevision: '',
        createTime: '',
        creativePreApprovalPolicy: '',
        creativeRestrictions: {
          creativeFormat: '',
          creativeSpecifications: [
            {
              creativeCompanionSizes: [{height: '', sizeType: '', width: ''}],
              creativeSize: {}
            }
          ],
          skippableAdType: ''
        },
        creativeSafeFrameCompatibility: '',
        dealId: '',
        dealServingMetadata: {
          dealPauseStatus: {
            buyerPauseReason: '',
            firstPausedBy: '',
            hasBuyerPaused: false,
            hasSellerPaused: false,
            sellerPauseReason: ''
          }
        },
        dealTerms: {
          brandingType: '',
          description: '',
          estimatedGrossSpend: {amount: {currencyCode: '', nanos: 0, units: ''}, pricingType: ''},
          estimatedImpressionsPerDay: '',
          guaranteedFixedPriceTerms: {
            fixedPrices: [{advertiserIds: [], buyer: {}, price: {}}],
            guaranteedImpressions: '',
            guaranteedLooks: '',
            impressionCap: '',
            minimumDailyLooks: '',
            percentShareOfVoice: '',
            reservationType: ''
          },
          nonGuaranteedAuctionTerms: {autoOptimizePrivateAuction: false, reservePricesPerBuyer: [{}]},
          nonGuaranteedFixedPriceTerms: {fixedPrices: [{}]},
          sellerTimeZone: ''
        },
        deliveryControl: {
          creativeBlockingLevel: '',
          deliveryRateType: '',
          frequencyCaps: [{maxImpressions: 0, numTimeUnits: 0, timeUnitType: ''}]
        },
        description: '',
        displayName: '',
        externalDealId: '',
        isSetupComplete: false,
        programmaticCreativeSource: '',
        proposalId: '',
        sellerContacts: [{}],
        syndicationProduct: '',
        targeting: {
          geoTargeting: {excludedCriteriaIds: [], targetedCriteriaIds: []},
          inventorySizeTargeting: {excludedInventorySizes: [{}], targetedInventorySizes: [{}]},
          placementTargeting: {
            mobileApplicationTargeting: {firstPartyTargeting: {excludedAppIds: [], targetedAppIds: []}},
            urlTargeting: {excludedUrls: [], targetedUrls: []}
          },
          technologyTargeting: {
            deviceCapabilityTargeting: {},
            deviceCategoryTargeting: {},
            operatingSystemTargeting: {operatingSystemCriteria: {}, operatingSystemVersionCriteria: {}}
          },
          videoTargeting: {excludedPositionTypes: [], targetedPositionTypes: []}
        },
        targetingCriterion: [
          {
            exclusions: [
              {
                creativeSizeValue: {
                  allowedFormats: [],
                  companionSizes: [{height: 0, width: 0}],
                  creativeSizeType: '',
                  nativeTemplate: '',
                  size: {},
                  skippableAdType: ''
                },
                dayPartTargetingValue: {
                  dayParts: [
                    {
                      dayOfWeek: '',
                      endTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
                      startTime: {}
                    }
                  ],
                  timeZoneType: ''
                },
                longValue: '',
                stringValue: ''
              }
            ],
            inclusions: [{}],
            key: ''
          }
        ],
        updateTime: '',
        webPropertyCode: ''
      }
    ],
    displayName: '',
    isRenegotiating: false,
    isSetupComplete: false,
    lastUpdaterOrCommentorRole: '',
    notes: [{createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}],
    originatorRole: '',
    privateAuctionId: '',
    proposalId: '',
    proposalRevision: '',
    proposalState: '',
    seller: {accountId: '', subAccountId: ''},
    sellerContacts: [{}],
    termsAndConditions: '',
    updateTime: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  billedBuyer: {
    accountId: ''
  },
  buyer: {},
  buyerContacts: [
    {
      email: '',
      name: ''
    }
  ],
  buyerPrivateData: {
    referenceId: ''
  },
  deals: [
    {
      availableEndTime: '',
      availableStartTime: '',
      buyerPrivateData: {},
      createProductId: '',
      createProductRevision: '',
      createTime: '',
      creativePreApprovalPolicy: '',
      creativeRestrictions: {
        creativeFormat: '',
        creativeSpecifications: [
          {
            creativeCompanionSizes: [
              {
                height: '',
                sizeType: '',
                width: ''
              }
            ],
            creativeSize: {}
          }
        ],
        skippableAdType: ''
      },
      creativeSafeFrameCompatibility: '',
      dealId: '',
      dealServingMetadata: {
        dealPauseStatus: {
          buyerPauseReason: '',
          firstPausedBy: '',
          hasBuyerPaused: false,
          hasSellerPaused: false,
          sellerPauseReason: ''
        }
      },
      dealTerms: {
        brandingType: '',
        description: '',
        estimatedGrossSpend: {
          amount: {
            currencyCode: '',
            nanos: 0,
            units: ''
          },
          pricingType: ''
        },
        estimatedImpressionsPerDay: '',
        guaranteedFixedPriceTerms: {
          fixedPrices: [
            {
              advertiserIds: [],
              buyer: {},
              price: {}
            }
          ],
          guaranteedImpressions: '',
          guaranteedLooks: '',
          impressionCap: '',
          minimumDailyLooks: '',
          percentShareOfVoice: '',
          reservationType: ''
        },
        nonGuaranteedAuctionTerms: {
          autoOptimizePrivateAuction: false,
          reservePricesPerBuyer: [
            {}
          ]
        },
        nonGuaranteedFixedPriceTerms: {
          fixedPrices: [
            {}
          ]
        },
        sellerTimeZone: ''
      },
      deliveryControl: {
        creativeBlockingLevel: '',
        deliveryRateType: '',
        frequencyCaps: [
          {
            maxImpressions: 0,
            numTimeUnits: 0,
            timeUnitType: ''
          }
        ]
      },
      description: '',
      displayName: '',
      externalDealId: '',
      isSetupComplete: false,
      programmaticCreativeSource: '',
      proposalId: '',
      sellerContacts: [
        {}
      ],
      syndicationProduct: '',
      targeting: {
        geoTargeting: {
          excludedCriteriaIds: [],
          targetedCriteriaIds: []
        },
        inventorySizeTargeting: {
          excludedInventorySizes: [
            {}
          ],
          targetedInventorySizes: [
            {}
          ]
        },
        placementTargeting: {
          mobileApplicationTargeting: {
            firstPartyTargeting: {
              excludedAppIds: [],
              targetedAppIds: []
            }
          },
          urlTargeting: {
            excludedUrls: [],
            targetedUrls: []
          }
        },
        technologyTargeting: {
          deviceCapabilityTargeting: {},
          deviceCategoryTargeting: {},
          operatingSystemTargeting: {
            operatingSystemCriteria: {},
            operatingSystemVersionCriteria: {}
          }
        },
        videoTargeting: {
          excludedPositionTypes: [],
          targetedPositionTypes: []
        }
      },
      targetingCriterion: [
        {
          exclusions: [
            {
              creativeSizeValue: {
                allowedFormats: [],
                companionSizes: [
                  {
                    height: 0,
                    width: 0
                  }
                ],
                creativeSizeType: '',
                nativeTemplate: '',
                size: {},
                skippableAdType: ''
              },
              dayPartTargetingValue: {
                dayParts: [
                  {
                    dayOfWeek: '',
                    endTime: {
                      hours: 0,
                      minutes: 0,
                      nanos: 0,
                      seconds: 0
                    },
                    startTime: {}
                  }
                ],
                timeZoneType: ''
              },
              longValue: '',
              stringValue: ''
            }
          ],
          inclusions: [
            {}
          ],
          key: ''
        }
      ],
      updateTime: '',
      webPropertyCode: ''
    }
  ],
  displayName: '',
  isRenegotiating: false,
  isSetupComplete: false,
  lastUpdaterOrCommentorRole: '',
  notes: [
    {
      createTime: '',
      creatorRole: '',
      note: '',
      noteId: '',
      proposalRevision: ''
    }
  ],
  originatorRole: '',
  privateAuctionId: '',
  proposalId: '',
  proposalRevision: '',
  proposalState: '',
  seller: {
    accountId: '',
    subAccountId: ''
  },
  sellerContacts: [
    {}
  ],
  termsAndConditions: '',
  updateTime: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals',
  headers: {'content-type': 'application/json'},
  data: {
    billedBuyer: {accountId: ''},
    buyer: {},
    buyerContacts: [{email: '', name: ''}],
    buyerPrivateData: {referenceId: ''},
    deals: [
      {
        availableEndTime: '',
        availableStartTime: '',
        buyerPrivateData: {},
        createProductId: '',
        createProductRevision: '',
        createTime: '',
        creativePreApprovalPolicy: '',
        creativeRestrictions: {
          creativeFormat: '',
          creativeSpecifications: [
            {
              creativeCompanionSizes: [{height: '', sizeType: '', width: ''}],
              creativeSize: {}
            }
          ],
          skippableAdType: ''
        },
        creativeSafeFrameCompatibility: '',
        dealId: '',
        dealServingMetadata: {
          dealPauseStatus: {
            buyerPauseReason: '',
            firstPausedBy: '',
            hasBuyerPaused: false,
            hasSellerPaused: false,
            sellerPauseReason: ''
          }
        },
        dealTerms: {
          brandingType: '',
          description: '',
          estimatedGrossSpend: {amount: {currencyCode: '', nanos: 0, units: ''}, pricingType: ''},
          estimatedImpressionsPerDay: '',
          guaranteedFixedPriceTerms: {
            fixedPrices: [{advertiserIds: [], buyer: {}, price: {}}],
            guaranteedImpressions: '',
            guaranteedLooks: '',
            impressionCap: '',
            minimumDailyLooks: '',
            percentShareOfVoice: '',
            reservationType: ''
          },
          nonGuaranteedAuctionTerms: {autoOptimizePrivateAuction: false, reservePricesPerBuyer: [{}]},
          nonGuaranteedFixedPriceTerms: {fixedPrices: [{}]},
          sellerTimeZone: ''
        },
        deliveryControl: {
          creativeBlockingLevel: '',
          deliveryRateType: '',
          frequencyCaps: [{maxImpressions: 0, numTimeUnits: 0, timeUnitType: ''}]
        },
        description: '',
        displayName: '',
        externalDealId: '',
        isSetupComplete: false,
        programmaticCreativeSource: '',
        proposalId: '',
        sellerContacts: [{}],
        syndicationProduct: '',
        targeting: {
          geoTargeting: {excludedCriteriaIds: [], targetedCriteriaIds: []},
          inventorySizeTargeting: {excludedInventorySizes: [{}], targetedInventorySizes: [{}]},
          placementTargeting: {
            mobileApplicationTargeting: {firstPartyTargeting: {excludedAppIds: [], targetedAppIds: []}},
            urlTargeting: {excludedUrls: [], targetedUrls: []}
          },
          technologyTargeting: {
            deviceCapabilityTargeting: {},
            deviceCategoryTargeting: {},
            operatingSystemTargeting: {operatingSystemCriteria: {}, operatingSystemVersionCriteria: {}}
          },
          videoTargeting: {excludedPositionTypes: [], targetedPositionTypes: []}
        },
        targetingCriterion: [
          {
            exclusions: [
              {
                creativeSizeValue: {
                  allowedFormats: [],
                  companionSizes: [{height: 0, width: 0}],
                  creativeSizeType: '',
                  nativeTemplate: '',
                  size: {},
                  skippableAdType: ''
                },
                dayPartTargetingValue: {
                  dayParts: [
                    {
                      dayOfWeek: '',
                      endTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
                      startTime: {}
                    }
                  ],
                  timeZoneType: ''
                },
                longValue: '',
                stringValue: ''
              }
            ],
            inclusions: [{}],
            key: ''
          }
        ],
        updateTime: '',
        webPropertyCode: ''
      }
    ],
    displayName: '',
    isRenegotiating: false,
    isSetupComplete: false,
    lastUpdaterOrCommentorRole: '',
    notes: [{createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}],
    originatorRole: '',
    privateAuctionId: '',
    proposalId: '',
    proposalRevision: '',
    proposalState: '',
    seller: {accountId: '', subAccountId: ''},
    sellerContacts: [{}],
    termsAndConditions: '',
    updateTime: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"billedBuyer":{"accountId":""},"buyer":{},"buyerContacts":[{"email":"","name":""}],"buyerPrivateData":{"referenceId":""},"deals":[{"availableEndTime":"","availableStartTime":"","buyerPrivateData":{},"createProductId":"","createProductRevision":"","createTime":"","creativePreApprovalPolicy":"","creativeRestrictions":{"creativeFormat":"","creativeSpecifications":[{"creativeCompanionSizes":[{"height":"","sizeType":"","width":""}],"creativeSize":{}}],"skippableAdType":""},"creativeSafeFrameCompatibility":"","dealId":"","dealServingMetadata":{"dealPauseStatus":{"buyerPauseReason":"","firstPausedBy":"","hasBuyerPaused":false,"hasSellerPaused":false,"sellerPauseReason":""}},"dealTerms":{"brandingType":"","description":"","estimatedGrossSpend":{"amount":{"currencyCode":"","nanos":0,"units":""},"pricingType":""},"estimatedImpressionsPerDay":"","guaranteedFixedPriceTerms":{"fixedPrices":[{"advertiserIds":[],"buyer":{},"price":{}}],"guaranteedImpressions":"","guaranteedLooks":"","impressionCap":"","minimumDailyLooks":"","percentShareOfVoice":"","reservationType":""},"nonGuaranteedAuctionTerms":{"autoOptimizePrivateAuction":false,"reservePricesPerBuyer":[{}]},"nonGuaranteedFixedPriceTerms":{"fixedPrices":[{}]},"sellerTimeZone":""},"deliveryControl":{"creativeBlockingLevel":"","deliveryRateType":"","frequencyCaps":[{"maxImpressions":0,"numTimeUnits":0,"timeUnitType":""}]},"description":"","displayName":"","externalDealId":"","isSetupComplete":false,"programmaticCreativeSource":"","proposalId":"","sellerContacts":[{}],"syndicationProduct":"","targeting":{"geoTargeting":{"excludedCriteriaIds":[],"targetedCriteriaIds":[]},"inventorySizeTargeting":{"excludedInventorySizes":[{}],"targetedInventorySizes":[{}]},"placementTargeting":{"mobileApplicationTargeting":{"firstPartyTargeting":{"excludedAppIds":[],"targetedAppIds":[]}},"urlTargeting":{"excludedUrls":[],"targetedUrls":[]}},"technologyTargeting":{"deviceCapabilityTargeting":{},"deviceCategoryTargeting":{},"operatingSystemTargeting":{"operatingSystemCriteria":{},"operatingSystemVersionCriteria":{}}},"videoTargeting":{"excludedPositionTypes":[],"targetedPositionTypes":[]}},"targetingCriterion":[{"exclusions":[{"creativeSizeValue":{"allowedFormats":[],"companionSizes":[{"height":0,"width":0}],"creativeSizeType":"","nativeTemplate":"","size":{},"skippableAdType":""},"dayPartTargetingValue":{"dayParts":[{"dayOfWeek":"","endTime":{"hours":0,"minutes":0,"nanos":0,"seconds":0},"startTime":{}}],"timeZoneType":""},"longValue":"","stringValue":""}],"inclusions":[{}],"key":""}],"updateTime":"","webPropertyCode":""}],"displayName":"","isRenegotiating":false,"isSetupComplete":false,"lastUpdaterOrCommentorRole":"","notes":[{"createTime":"","creatorRole":"","note":"","noteId":"","proposalRevision":""}],"originatorRole":"","privateAuctionId":"","proposalId":"","proposalRevision":"","proposalState":"","seller":{"accountId":"","subAccountId":""},"sellerContacts":[{}],"termsAndConditions":"","updateTime":""}'
};

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 = @{ @"billedBuyer": @{ @"accountId": @"" },
                              @"buyer": @{  },
                              @"buyerContacts": @[ @{ @"email": @"", @"name": @"" } ],
                              @"buyerPrivateData": @{ @"referenceId": @"" },
                              @"deals": @[ @{ @"availableEndTime": @"", @"availableStartTime": @"", @"buyerPrivateData": @{  }, @"createProductId": @"", @"createProductRevision": @"", @"createTime": @"", @"creativePreApprovalPolicy": @"", @"creativeRestrictions": @{ @"creativeFormat": @"", @"creativeSpecifications": @[ @{ @"creativeCompanionSizes": @[ @{ @"height": @"", @"sizeType": @"", @"width": @"" } ], @"creativeSize": @{  } } ], @"skippableAdType": @"" }, @"creativeSafeFrameCompatibility": @"", @"dealId": @"", @"dealServingMetadata": @{ @"dealPauseStatus": @{ @"buyerPauseReason": @"", @"firstPausedBy": @"", @"hasBuyerPaused": @NO, @"hasSellerPaused": @NO, @"sellerPauseReason": @"" } }, @"dealTerms": @{ @"brandingType": @"", @"description": @"", @"estimatedGrossSpend": @{ @"amount": @{ @"currencyCode": @"", @"nanos": @0, @"units": @"" }, @"pricingType": @"" }, @"estimatedImpressionsPerDay": @"", @"guaranteedFixedPriceTerms": @{ @"fixedPrices": @[ @{ @"advertiserIds": @[  ], @"buyer": @{  }, @"price": @{  } } ], @"guaranteedImpressions": @"", @"guaranteedLooks": @"", @"impressionCap": @"", @"minimumDailyLooks": @"", @"percentShareOfVoice": @"", @"reservationType": @"" }, @"nonGuaranteedAuctionTerms": @{ @"autoOptimizePrivateAuction": @NO, @"reservePricesPerBuyer": @[ @{  } ] }, @"nonGuaranteedFixedPriceTerms": @{ @"fixedPrices": @[ @{  } ] }, @"sellerTimeZone": @"" }, @"deliveryControl": @{ @"creativeBlockingLevel": @"", @"deliveryRateType": @"", @"frequencyCaps": @[ @{ @"maxImpressions": @0, @"numTimeUnits": @0, @"timeUnitType": @"" } ] }, @"description": @"", @"displayName": @"", @"externalDealId": @"", @"isSetupComplete": @NO, @"programmaticCreativeSource": @"", @"proposalId": @"", @"sellerContacts": @[ @{  } ], @"syndicationProduct": @"", @"targeting": @{ @"geoTargeting": @{ @"excludedCriteriaIds": @[  ], @"targetedCriteriaIds": @[  ] }, @"inventorySizeTargeting": @{ @"excludedInventorySizes": @[ @{  } ], @"targetedInventorySizes": @[ @{  } ] }, @"placementTargeting": @{ @"mobileApplicationTargeting": @{ @"firstPartyTargeting": @{ @"excludedAppIds": @[  ], @"targetedAppIds": @[  ] } }, @"urlTargeting": @{ @"excludedUrls": @[  ], @"targetedUrls": @[  ] } }, @"technologyTargeting": @{ @"deviceCapabilityTargeting": @{  }, @"deviceCategoryTargeting": @{  }, @"operatingSystemTargeting": @{ @"operatingSystemCriteria": @{  }, @"operatingSystemVersionCriteria": @{  } } }, @"videoTargeting": @{ @"excludedPositionTypes": @[  ], @"targetedPositionTypes": @[  ] } }, @"targetingCriterion": @[ @{ @"exclusions": @[ @{ @"creativeSizeValue": @{ @"allowedFormats": @[  ], @"companionSizes": @[ @{ @"height": @0, @"width": @0 } ], @"creativeSizeType": @"", @"nativeTemplate": @"", @"size": @{  }, @"skippableAdType": @"" }, @"dayPartTargetingValue": @{ @"dayParts": @[ @{ @"dayOfWeek": @"", @"endTime": @{ @"hours": @0, @"minutes": @0, @"nanos": @0, @"seconds": @0 }, @"startTime": @{  } } ], @"timeZoneType": @"" }, @"longValue": @"", @"stringValue": @"" } ], @"inclusions": @[ @{  } ], @"key": @"" } ], @"updateTime": @"", @"webPropertyCode": @"" } ],
                              @"displayName": @"",
                              @"isRenegotiating": @NO,
                              @"isSetupComplete": @NO,
                              @"lastUpdaterOrCommentorRole": @"",
                              @"notes": @[ @{ @"createTime": @"", @"creatorRole": @"", @"note": @"", @"noteId": @"", @"proposalRevision": @"" } ],
                              @"originatorRole": @"",
                              @"privateAuctionId": @"",
                              @"proposalId": @"",
                              @"proposalRevision": @"",
                              @"proposalState": @"",
                              @"seller": @{ @"accountId": @"", @"subAccountId": @"" },
                              @"sellerContacts": @[ @{  } ],
                              @"termsAndConditions": @"",
                              @"updateTime": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/proposals"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/proposals" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/proposals",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'billedBuyer' => [
        'accountId' => ''
    ],
    'buyer' => [
        
    ],
    'buyerContacts' => [
        [
                'email' => '',
                'name' => ''
        ]
    ],
    'buyerPrivateData' => [
        'referenceId' => ''
    ],
    'deals' => [
        [
                'availableEndTime' => '',
                'availableStartTime' => '',
                'buyerPrivateData' => [
                                
                ],
                'createProductId' => '',
                'createProductRevision' => '',
                'createTime' => '',
                'creativePreApprovalPolicy' => '',
                'creativeRestrictions' => [
                                'creativeFormat' => '',
                                'creativeSpecifications' => [
                                                                [
                                                                                                                                'creativeCompanionSizes' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'height' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'sizeType' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'width' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'creativeSize' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'skippableAdType' => ''
                ],
                'creativeSafeFrameCompatibility' => '',
                'dealId' => '',
                'dealServingMetadata' => [
                                'dealPauseStatus' => [
                                                                'buyerPauseReason' => '',
                                                                'firstPausedBy' => '',
                                                                'hasBuyerPaused' => null,
                                                                'hasSellerPaused' => null,
                                                                'sellerPauseReason' => ''
                                ]
                ],
                'dealTerms' => [
                                'brandingType' => '',
                                'description' => '',
                                'estimatedGrossSpend' => [
                                                                'amount' => [
                                                                                                                                'currencyCode' => '',
                                                                                                                                'nanos' => 0,
                                                                                                                                'units' => ''
                                                                ],
                                                                'pricingType' => ''
                                ],
                                'estimatedImpressionsPerDay' => '',
                                'guaranteedFixedPriceTerms' => [
                                                                'fixedPrices' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'advertiserIds' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'buyer' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'price' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'guaranteedImpressions' => '',
                                                                'guaranteedLooks' => '',
                                                                'impressionCap' => '',
                                                                'minimumDailyLooks' => '',
                                                                'percentShareOfVoice' => '',
                                                                'reservationType' => ''
                                ],
                                'nonGuaranteedAuctionTerms' => [
                                                                'autoOptimizePrivateAuction' => null,
                                                                'reservePricesPerBuyer' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'nonGuaranteedFixedPriceTerms' => [
                                                                'fixedPrices' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'sellerTimeZone' => ''
                ],
                'deliveryControl' => [
                                'creativeBlockingLevel' => '',
                                'deliveryRateType' => '',
                                'frequencyCaps' => [
                                                                [
                                                                                                                                'maxImpressions' => 0,
                                                                                                                                'numTimeUnits' => 0,
                                                                                                                                'timeUnitType' => ''
                                                                ]
                                ]
                ],
                'description' => '',
                'displayName' => '',
                'externalDealId' => '',
                'isSetupComplete' => null,
                'programmaticCreativeSource' => '',
                'proposalId' => '',
                'sellerContacts' => [
                                [
                                                                
                                ]
                ],
                'syndicationProduct' => '',
                'targeting' => [
                                'geoTargeting' => [
                                                                'excludedCriteriaIds' => [
                                                                                                                                
                                                                ],
                                                                'targetedCriteriaIds' => [
                                                                                                                                
                                                                ]
                                ],
                                'inventorySizeTargeting' => [
                                                                'excludedInventorySizes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'targetedInventorySizes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'placementTargeting' => [
                                                                'mobileApplicationTargeting' => [
                                                                                                                                'firstPartyTargeting' => [
                                                                                                                                                                                                                                                                'excludedAppIds' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'targetedAppIds' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'urlTargeting' => [
                                                                                                                                'excludedUrls' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'targetedUrls' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'technologyTargeting' => [
                                                                'deviceCapabilityTargeting' => [
                                                                                                                                
                                                                ],
                                                                'deviceCategoryTargeting' => [
                                                                                                                                
                                                                ],
                                                                'operatingSystemTargeting' => [
                                                                                                                                'operatingSystemCriteria' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'operatingSystemVersionCriteria' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'videoTargeting' => [
                                                                'excludedPositionTypes' => [
                                                                                                                                
                                                                ],
                                                                'targetedPositionTypes' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'targetingCriterion' => [
                                [
                                                                'exclusions' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'creativeSizeValue' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'allowedFormats' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'companionSizes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'creativeSizeType' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'nativeTemplate' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'size' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'skippableAdType' => ''
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'dayPartTargetingValue' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'dayParts' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'dayOfWeek' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'endTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'hours' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'minutes' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'nanos' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'seconds' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'startTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'timeZoneType' => ''
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'longValue' => '',
                                                                                                                                                                                                                                                                'stringValue' => ''
                                                                                                                                ]
                                                                ],
                                                                'inclusions' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'key' => ''
                                ]
                ],
                'updateTime' => '',
                'webPropertyCode' => ''
        ]
    ],
    'displayName' => '',
    'isRenegotiating' => null,
    'isSetupComplete' => null,
    'lastUpdaterOrCommentorRole' => '',
    'notes' => [
        [
                'createTime' => '',
                'creatorRole' => '',
                'note' => '',
                'noteId' => '',
                'proposalRevision' => ''
        ]
    ],
    'originatorRole' => '',
    'privateAuctionId' => '',
    'proposalId' => '',
    'proposalRevision' => '',
    'proposalState' => '',
    'seller' => [
        'accountId' => '',
        'subAccountId' => ''
    ],
    'sellerContacts' => [
        [
                
        ]
    ],
    'termsAndConditions' => '',
    'updateTime' => ''
  ]),
  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}}/v2beta1/accounts/:accountId/proposals', [
  'body' => '{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'billedBuyer' => [
    'accountId' => ''
  ],
  'buyer' => [
    
  ],
  'buyerContacts' => [
    [
        'email' => '',
        'name' => ''
    ]
  ],
  'buyerPrivateData' => [
    'referenceId' => ''
  ],
  'deals' => [
    [
        'availableEndTime' => '',
        'availableStartTime' => '',
        'buyerPrivateData' => [
                
        ],
        'createProductId' => '',
        'createProductRevision' => '',
        'createTime' => '',
        'creativePreApprovalPolicy' => '',
        'creativeRestrictions' => [
                'creativeFormat' => '',
                'creativeSpecifications' => [
                                [
                                                                'creativeCompanionSizes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'height' => '',
                                                                                                                                                                                                                                                                'sizeType' => '',
                                                                                                                                                                                                                                                                'width' => ''
                                                                                                                                ]
                                                                ],
                                                                'creativeSize' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'skippableAdType' => ''
        ],
        'creativeSafeFrameCompatibility' => '',
        'dealId' => '',
        'dealServingMetadata' => [
                'dealPauseStatus' => [
                                'buyerPauseReason' => '',
                                'firstPausedBy' => '',
                                'hasBuyerPaused' => null,
                                'hasSellerPaused' => null,
                                'sellerPauseReason' => ''
                ]
        ],
        'dealTerms' => [
                'brandingType' => '',
                'description' => '',
                'estimatedGrossSpend' => [
                                'amount' => [
                                                                'currencyCode' => '',
                                                                'nanos' => 0,
                                                                'units' => ''
                                ],
                                'pricingType' => ''
                ],
                'estimatedImpressionsPerDay' => '',
                'guaranteedFixedPriceTerms' => [
                                'fixedPrices' => [
                                                                [
                                                                                                                                'advertiserIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'buyer' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'price' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'guaranteedImpressions' => '',
                                'guaranteedLooks' => '',
                                'impressionCap' => '',
                                'minimumDailyLooks' => '',
                                'percentShareOfVoice' => '',
                                'reservationType' => ''
                ],
                'nonGuaranteedAuctionTerms' => [
                                'autoOptimizePrivateAuction' => null,
                                'reservePricesPerBuyer' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'nonGuaranteedFixedPriceTerms' => [
                                'fixedPrices' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'sellerTimeZone' => ''
        ],
        'deliveryControl' => [
                'creativeBlockingLevel' => '',
                'deliveryRateType' => '',
                'frequencyCaps' => [
                                [
                                                                'maxImpressions' => 0,
                                                                'numTimeUnits' => 0,
                                                                'timeUnitType' => ''
                                ]
                ]
        ],
        'description' => '',
        'displayName' => '',
        'externalDealId' => '',
        'isSetupComplete' => null,
        'programmaticCreativeSource' => '',
        'proposalId' => '',
        'sellerContacts' => [
                [
                                
                ]
        ],
        'syndicationProduct' => '',
        'targeting' => [
                'geoTargeting' => [
                                'excludedCriteriaIds' => [
                                                                
                                ],
                                'targetedCriteriaIds' => [
                                                                
                                ]
                ],
                'inventorySizeTargeting' => [
                                'excludedInventorySizes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'targetedInventorySizes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'placementTargeting' => [
                                'mobileApplicationTargeting' => [
                                                                'firstPartyTargeting' => [
                                                                                                                                'excludedAppIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'targetedAppIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'urlTargeting' => [
                                                                'excludedUrls' => [
                                                                                                                                
                                                                ],
                                                                'targetedUrls' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'technologyTargeting' => [
                                'deviceCapabilityTargeting' => [
                                                                
                                ],
                                'deviceCategoryTargeting' => [
                                                                
                                ],
                                'operatingSystemTargeting' => [
                                                                'operatingSystemCriteria' => [
                                                                                                                                
                                                                ],
                                                                'operatingSystemVersionCriteria' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'videoTargeting' => [
                                'excludedPositionTypes' => [
                                                                
                                ],
                                'targetedPositionTypes' => [
                                                                
                                ]
                ]
        ],
        'targetingCriterion' => [
                [
                                'exclusions' => [
                                                                [
                                                                                                                                'creativeSizeValue' => [
                                                                                                                                                                                                                                                                'allowedFormats' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'companionSizes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'creativeSizeType' => '',
                                                                                                                                                                                                                                                                'nativeTemplate' => '',
                                                                                                                                                                                                                                                                'size' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'skippableAdType' => ''
                                                                                                                                ],
                                                                                                                                'dayPartTargetingValue' => [
                                                                                                                                                                                                                                                                'dayParts' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'dayOfWeek' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'endTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'hours' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'minutes' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'nanos' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'seconds' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'startTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'timeZoneType' => ''
                                                                                                                                ],
                                                                                                                                'longValue' => '',
                                                                                                                                'stringValue' => ''
                                                                ]
                                ],
                                'inclusions' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'key' => ''
                ]
        ],
        'updateTime' => '',
        'webPropertyCode' => ''
    ]
  ],
  'displayName' => '',
  'isRenegotiating' => null,
  'isSetupComplete' => null,
  'lastUpdaterOrCommentorRole' => '',
  'notes' => [
    [
        'createTime' => '',
        'creatorRole' => '',
        'note' => '',
        'noteId' => '',
        'proposalRevision' => ''
    ]
  ],
  'originatorRole' => '',
  'privateAuctionId' => '',
  'proposalId' => '',
  'proposalRevision' => '',
  'proposalState' => '',
  'seller' => [
    'accountId' => '',
    'subAccountId' => ''
  ],
  'sellerContacts' => [
    [
        
    ]
  ],
  'termsAndConditions' => '',
  'updateTime' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'billedBuyer' => [
    'accountId' => ''
  ],
  'buyer' => [
    
  ],
  'buyerContacts' => [
    [
        'email' => '',
        'name' => ''
    ]
  ],
  'buyerPrivateData' => [
    'referenceId' => ''
  ],
  'deals' => [
    [
        'availableEndTime' => '',
        'availableStartTime' => '',
        'buyerPrivateData' => [
                
        ],
        'createProductId' => '',
        'createProductRevision' => '',
        'createTime' => '',
        'creativePreApprovalPolicy' => '',
        'creativeRestrictions' => [
                'creativeFormat' => '',
                'creativeSpecifications' => [
                                [
                                                                'creativeCompanionSizes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'height' => '',
                                                                                                                                                                                                                                                                'sizeType' => '',
                                                                                                                                                                                                                                                                'width' => ''
                                                                                                                                ]
                                                                ],
                                                                'creativeSize' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'skippableAdType' => ''
        ],
        'creativeSafeFrameCompatibility' => '',
        'dealId' => '',
        'dealServingMetadata' => [
                'dealPauseStatus' => [
                                'buyerPauseReason' => '',
                                'firstPausedBy' => '',
                                'hasBuyerPaused' => null,
                                'hasSellerPaused' => null,
                                'sellerPauseReason' => ''
                ]
        ],
        'dealTerms' => [
                'brandingType' => '',
                'description' => '',
                'estimatedGrossSpend' => [
                                'amount' => [
                                                                'currencyCode' => '',
                                                                'nanos' => 0,
                                                                'units' => ''
                                ],
                                'pricingType' => ''
                ],
                'estimatedImpressionsPerDay' => '',
                'guaranteedFixedPriceTerms' => [
                                'fixedPrices' => [
                                                                [
                                                                                                                                'advertiserIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'buyer' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'price' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'guaranteedImpressions' => '',
                                'guaranteedLooks' => '',
                                'impressionCap' => '',
                                'minimumDailyLooks' => '',
                                'percentShareOfVoice' => '',
                                'reservationType' => ''
                ],
                'nonGuaranteedAuctionTerms' => [
                                'autoOptimizePrivateAuction' => null,
                                'reservePricesPerBuyer' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'nonGuaranteedFixedPriceTerms' => [
                                'fixedPrices' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'sellerTimeZone' => ''
        ],
        'deliveryControl' => [
                'creativeBlockingLevel' => '',
                'deliveryRateType' => '',
                'frequencyCaps' => [
                                [
                                                                'maxImpressions' => 0,
                                                                'numTimeUnits' => 0,
                                                                'timeUnitType' => ''
                                ]
                ]
        ],
        'description' => '',
        'displayName' => '',
        'externalDealId' => '',
        'isSetupComplete' => null,
        'programmaticCreativeSource' => '',
        'proposalId' => '',
        'sellerContacts' => [
                [
                                
                ]
        ],
        'syndicationProduct' => '',
        'targeting' => [
                'geoTargeting' => [
                                'excludedCriteriaIds' => [
                                                                
                                ],
                                'targetedCriteriaIds' => [
                                                                
                                ]
                ],
                'inventorySizeTargeting' => [
                                'excludedInventorySizes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'targetedInventorySizes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'placementTargeting' => [
                                'mobileApplicationTargeting' => [
                                                                'firstPartyTargeting' => [
                                                                                                                                'excludedAppIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'targetedAppIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'urlTargeting' => [
                                                                'excludedUrls' => [
                                                                                                                                
                                                                ],
                                                                'targetedUrls' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'technologyTargeting' => [
                                'deviceCapabilityTargeting' => [
                                                                
                                ],
                                'deviceCategoryTargeting' => [
                                                                
                                ],
                                'operatingSystemTargeting' => [
                                                                'operatingSystemCriteria' => [
                                                                                                                                
                                                                ],
                                                                'operatingSystemVersionCriteria' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'videoTargeting' => [
                                'excludedPositionTypes' => [
                                                                
                                ],
                                'targetedPositionTypes' => [
                                                                
                                ]
                ]
        ],
        'targetingCriterion' => [
                [
                                'exclusions' => [
                                                                [
                                                                                                                                'creativeSizeValue' => [
                                                                                                                                                                                                                                                                'allowedFormats' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'companionSizes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'creativeSizeType' => '',
                                                                                                                                                                                                                                                                'nativeTemplate' => '',
                                                                                                                                                                                                                                                                'size' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'skippableAdType' => ''
                                                                                                                                ],
                                                                                                                                'dayPartTargetingValue' => [
                                                                                                                                                                                                                                                                'dayParts' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'dayOfWeek' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'endTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'hours' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'minutes' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'nanos' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'seconds' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'startTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'timeZoneType' => ''
                                                                                                                                ],
                                                                                                                                'longValue' => '',
                                                                                                                                'stringValue' => ''
                                                                ]
                                ],
                                'inclusions' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'key' => ''
                ]
        ],
        'updateTime' => '',
        'webPropertyCode' => ''
    ]
  ],
  'displayName' => '',
  'isRenegotiating' => null,
  'isSetupComplete' => null,
  'lastUpdaterOrCommentorRole' => '',
  'notes' => [
    [
        'createTime' => '',
        'creatorRole' => '',
        'note' => '',
        'noteId' => '',
        'proposalRevision' => ''
    ]
  ],
  'originatorRole' => '',
  'privateAuctionId' => '',
  'proposalId' => '',
  'proposalRevision' => '',
  'proposalState' => '',
  'seller' => [
    'accountId' => '',
    'subAccountId' => ''
  ],
  'sellerContacts' => [
    [
        
    ]
  ],
  'termsAndConditions' => '',
  'updateTime' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals');
$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}}/v2beta1/accounts/:accountId/proposals' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/proposals' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/proposals", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals"

payload = {
    "billedBuyer": { "accountId": "" },
    "buyer": {},
    "buyerContacts": [
        {
            "email": "",
            "name": ""
        }
    ],
    "buyerPrivateData": { "referenceId": "" },
    "deals": [
        {
            "availableEndTime": "",
            "availableStartTime": "",
            "buyerPrivateData": {},
            "createProductId": "",
            "createProductRevision": "",
            "createTime": "",
            "creativePreApprovalPolicy": "",
            "creativeRestrictions": {
                "creativeFormat": "",
                "creativeSpecifications": [
                    {
                        "creativeCompanionSizes": [
                            {
                                "height": "",
                                "sizeType": "",
                                "width": ""
                            }
                        ],
                        "creativeSize": {}
                    }
                ],
                "skippableAdType": ""
            },
            "creativeSafeFrameCompatibility": "",
            "dealId": "",
            "dealServingMetadata": { "dealPauseStatus": {
                    "buyerPauseReason": "",
                    "firstPausedBy": "",
                    "hasBuyerPaused": False,
                    "hasSellerPaused": False,
                    "sellerPauseReason": ""
                } },
            "dealTerms": {
                "brandingType": "",
                "description": "",
                "estimatedGrossSpend": {
                    "amount": {
                        "currencyCode": "",
                        "nanos": 0,
                        "units": ""
                    },
                    "pricingType": ""
                },
                "estimatedImpressionsPerDay": "",
                "guaranteedFixedPriceTerms": {
                    "fixedPrices": [
                        {
                            "advertiserIds": [],
                            "buyer": {},
                            "price": {}
                        }
                    ],
                    "guaranteedImpressions": "",
                    "guaranteedLooks": "",
                    "impressionCap": "",
                    "minimumDailyLooks": "",
                    "percentShareOfVoice": "",
                    "reservationType": ""
                },
                "nonGuaranteedAuctionTerms": {
                    "autoOptimizePrivateAuction": False,
                    "reservePricesPerBuyer": [{}]
                },
                "nonGuaranteedFixedPriceTerms": { "fixedPrices": [{}] },
                "sellerTimeZone": ""
            },
            "deliveryControl": {
                "creativeBlockingLevel": "",
                "deliveryRateType": "",
                "frequencyCaps": [
                    {
                        "maxImpressions": 0,
                        "numTimeUnits": 0,
                        "timeUnitType": ""
                    }
                ]
            },
            "description": "",
            "displayName": "",
            "externalDealId": "",
            "isSetupComplete": False,
            "programmaticCreativeSource": "",
            "proposalId": "",
            "sellerContacts": [{}],
            "syndicationProduct": "",
            "targeting": {
                "geoTargeting": {
                    "excludedCriteriaIds": [],
                    "targetedCriteriaIds": []
                },
                "inventorySizeTargeting": {
                    "excludedInventorySizes": [{}],
                    "targetedInventorySizes": [{}]
                },
                "placementTargeting": {
                    "mobileApplicationTargeting": { "firstPartyTargeting": {
                            "excludedAppIds": [],
                            "targetedAppIds": []
                        } },
                    "urlTargeting": {
                        "excludedUrls": [],
                        "targetedUrls": []
                    }
                },
                "technologyTargeting": {
                    "deviceCapabilityTargeting": {},
                    "deviceCategoryTargeting": {},
                    "operatingSystemTargeting": {
                        "operatingSystemCriteria": {},
                        "operatingSystemVersionCriteria": {}
                    }
                },
                "videoTargeting": {
                    "excludedPositionTypes": [],
                    "targetedPositionTypes": []
                }
            },
            "targetingCriterion": [
                {
                    "exclusions": [
                        {
                            "creativeSizeValue": {
                                "allowedFormats": [],
                                "companionSizes": [
                                    {
                                        "height": 0,
                                        "width": 0
                                    }
                                ],
                                "creativeSizeType": "",
                                "nativeTemplate": "",
                                "size": {},
                                "skippableAdType": ""
                            },
                            "dayPartTargetingValue": {
                                "dayParts": [
                                    {
                                        "dayOfWeek": "",
                                        "endTime": {
                                            "hours": 0,
                                            "minutes": 0,
                                            "nanos": 0,
                                            "seconds": 0
                                        },
                                        "startTime": {}
                                    }
                                ],
                                "timeZoneType": ""
                            },
                            "longValue": "",
                            "stringValue": ""
                        }
                    ],
                    "inclusions": [{}],
                    "key": ""
                }
            ],
            "updateTime": "",
            "webPropertyCode": ""
        }
    ],
    "displayName": "",
    "isRenegotiating": False,
    "isSetupComplete": False,
    "lastUpdaterOrCommentorRole": "",
    "notes": [
        {
            "createTime": "",
            "creatorRole": "",
            "note": "",
            "noteId": "",
            "proposalRevision": ""
        }
    ],
    "originatorRole": "",
    "privateAuctionId": "",
    "proposalId": "",
    "proposalRevision": "",
    "proposalState": "",
    "seller": {
        "accountId": "",
        "subAccountId": ""
    },
    "sellerContacts": [{}],
    "termsAndConditions": "",
    "updateTime": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/proposals"

payload <- "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\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}}/v2beta1/accounts/:accountId/proposals")

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  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/proposals') do |req|
  req.body = "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals";

    let payload = json!({
        "billedBuyer": json!({"accountId": ""}),
        "buyer": json!({}),
        "buyerContacts": (
            json!({
                "email": "",
                "name": ""
            })
        ),
        "buyerPrivateData": json!({"referenceId": ""}),
        "deals": (
            json!({
                "availableEndTime": "",
                "availableStartTime": "",
                "buyerPrivateData": json!({}),
                "createProductId": "",
                "createProductRevision": "",
                "createTime": "",
                "creativePreApprovalPolicy": "",
                "creativeRestrictions": json!({
                    "creativeFormat": "",
                    "creativeSpecifications": (
                        json!({
                            "creativeCompanionSizes": (
                                json!({
                                    "height": "",
                                    "sizeType": "",
                                    "width": ""
                                })
                            ),
                            "creativeSize": json!({})
                        })
                    ),
                    "skippableAdType": ""
                }),
                "creativeSafeFrameCompatibility": "",
                "dealId": "",
                "dealServingMetadata": json!({"dealPauseStatus": json!({
                        "buyerPauseReason": "",
                        "firstPausedBy": "",
                        "hasBuyerPaused": false,
                        "hasSellerPaused": false,
                        "sellerPauseReason": ""
                    })}),
                "dealTerms": json!({
                    "brandingType": "",
                    "description": "",
                    "estimatedGrossSpend": json!({
                        "amount": json!({
                            "currencyCode": "",
                            "nanos": 0,
                            "units": ""
                        }),
                        "pricingType": ""
                    }),
                    "estimatedImpressionsPerDay": "",
                    "guaranteedFixedPriceTerms": json!({
                        "fixedPrices": (
                            json!({
                                "advertiserIds": (),
                                "buyer": json!({}),
                                "price": json!({})
                            })
                        ),
                        "guaranteedImpressions": "",
                        "guaranteedLooks": "",
                        "impressionCap": "",
                        "minimumDailyLooks": "",
                        "percentShareOfVoice": "",
                        "reservationType": ""
                    }),
                    "nonGuaranteedAuctionTerms": json!({
                        "autoOptimizePrivateAuction": false,
                        "reservePricesPerBuyer": (json!({}))
                    }),
                    "nonGuaranteedFixedPriceTerms": json!({"fixedPrices": (json!({}))}),
                    "sellerTimeZone": ""
                }),
                "deliveryControl": json!({
                    "creativeBlockingLevel": "",
                    "deliveryRateType": "",
                    "frequencyCaps": (
                        json!({
                            "maxImpressions": 0,
                            "numTimeUnits": 0,
                            "timeUnitType": ""
                        })
                    )
                }),
                "description": "",
                "displayName": "",
                "externalDealId": "",
                "isSetupComplete": false,
                "programmaticCreativeSource": "",
                "proposalId": "",
                "sellerContacts": (json!({})),
                "syndicationProduct": "",
                "targeting": json!({
                    "geoTargeting": json!({
                        "excludedCriteriaIds": (),
                        "targetedCriteriaIds": ()
                    }),
                    "inventorySizeTargeting": json!({
                        "excludedInventorySizes": (json!({})),
                        "targetedInventorySizes": (json!({}))
                    }),
                    "placementTargeting": json!({
                        "mobileApplicationTargeting": json!({"firstPartyTargeting": json!({
                                "excludedAppIds": (),
                                "targetedAppIds": ()
                            })}),
                        "urlTargeting": json!({
                            "excludedUrls": (),
                            "targetedUrls": ()
                        })
                    }),
                    "technologyTargeting": json!({
                        "deviceCapabilityTargeting": json!({}),
                        "deviceCategoryTargeting": json!({}),
                        "operatingSystemTargeting": json!({
                            "operatingSystemCriteria": json!({}),
                            "operatingSystemVersionCriteria": json!({})
                        })
                    }),
                    "videoTargeting": json!({
                        "excludedPositionTypes": (),
                        "targetedPositionTypes": ()
                    })
                }),
                "targetingCriterion": (
                    json!({
                        "exclusions": (
                            json!({
                                "creativeSizeValue": json!({
                                    "allowedFormats": (),
                                    "companionSizes": (
                                        json!({
                                            "height": 0,
                                            "width": 0
                                        })
                                    ),
                                    "creativeSizeType": "",
                                    "nativeTemplate": "",
                                    "size": json!({}),
                                    "skippableAdType": ""
                                }),
                                "dayPartTargetingValue": json!({
                                    "dayParts": (
                                        json!({
                                            "dayOfWeek": "",
                                            "endTime": json!({
                                                "hours": 0,
                                                "minutes": 0,
                                                "nanos": 0,
                                                "seconds": 0
                                            }),
                                            "startTime": json!({})
                                        })
                                    ),
                                    "timeZoneType": ""
                                }),
                                "longValue": "",
                                "stringValue": ""
                            })
                        ),
                        "inclusions": (json!({})),
                        "key": ""
                    })
                ),
                "updateTime": "",
                "webPropertyCode": ""
            })
        ),
        "displayName": "",
        "isRenegotiating": false,
        "isSetupComplete": false,
        "lastUpdaterOrCommentorRole": "",
        "notes": (
            json!({
                "createTime": "",
                "creatorRole": "",
                "note": "",
                "noteId": "",
                "proposalRevision": ""
            })
        ),
        "originatorRole": "",
        "privateAuctionId": "",
        "proposalId": "",
        "proposalRevision": "",
        "proposalState": "",
        "seller": json!({
            "accountId": "",
            "subAccountId": ""
        }),
        "sellerContacts": (json!({})),
        "termsAndConditions": "",
        "updateTime": ""
    });

    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}}/v2beta1/accounts/:accountId/proposals \
  --header 'content-type: application/json' \
  --data '{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}'
echo '{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/proposals \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "billedBuyer": {\n    "accountId": ""\n  },\n  "buyer": {},\n  "buyerContacts": [\n    {\n      "email": "",\n      "name": ""\n    }\n  ],\n  "buyerPrivateData": {\n    "referenceId": ""\n  },\n  "deals": [\n    {\n      "availableEndTime": "",\n      "availableStartTime": "",\n      "buyerPrivateData": {},\n      "createProductId": "",\n      "createProductRevision": "",\n      "createTime": "",\n      "creativePreApprovalPolicy": "",\n      "creativeRestrictions": {\n        "creativeFormat": "",\n        "creativeSpecifications": [\n          {\n            "creativeCompanionSizes": [\n              {\n                "height": "",\n                "sizeType": "",\n                "width": ""\n              }\n            ],\n            "creativeSize": {}\n          }\n        ],\n        "skippableAdType": ""\n      },\n      "creativeSafeFrameCompatibility": "",\n      "dealId": "",\n      "dealServingMetadata": {\n        "dealPauseStatus": {\n          "buyerPauseReason": "",\n          "firstPausedBy": "",\n          "hasBuyerPaused": false,\n          "hasSellerPaused": false,\n          "sellerPauseReason": ""\n        }\n      },\n      "dealTerms": {\n        "brandingType": "",\n        "description": "",\n        "estimatedGrossSpend": {\n          "amount": {\n            "currencyCode": "",\n            "nanos": 0,\n            "units": ""\n          },\n          "pricingType": ""\n        },\n        "estimatedImpressionsPerDay": "",\n        "guaranteedFixedPriceTerms": {\n          "fixedPrices": [\n            {\n              "advertiserIds": [],\n              "buyer": {},\n              "price": {}\n            }\n          ],\n          "guaranteedImpressions": "",\n          "guaranteedLooks": "",\n          "impressionCap": "",\n          "minimumDailyLooks": "",\n          "percentShareOfVoice": "",\n          "reservationType": ""\n        },\n        "nonGuaranteedAuctionTerms": {\n          "autoOptimizePrivateAuction": false,\n          "reservePricesPerBuyer": [\n            {}\n          ]\n        },\n        "nonGuaranteedFixedPriceTerms": {\n          "fixedPrices": [\n            {}\n          ]\n        },\n        "sellerTimeZone": ""\n      },\n      "deliveryControl": {\n        "creativeBlockingLevel": "",\n        "deliveryRateType": "",\n        "frequencyCaps": [\n          {\n            "maxImpressions": 0,\n            "numTimeUnits": 0,\n            "timeUnitType": ""\n          }\n        ]\n      },\n      "description": "",\n      "displayName": "",\n      "externalDealId": "",\n      "isSetupComplete": false,\n      "programmaticCreativeSource": "",\n      "proposalId": "",\n      "sellerContacts": [\n        {}\n      ],\n      "syndicationProduct": "",\n      "targeting": {\n        "geoTargeting": {\n          "excludedCriteriaIds": [],\n          "targetedCriteriaIds": []\n        },\n        "inventorySizeTargeting": {\n          "excludedInventorySizes": [\n            {}\n          ],\n          "targetedInventorySizes": [\n            {}\n          ]\n        },\n        "placementTargeting": {\n          "mobileApplicationTargeting": {\n            "firstPartyTargeting": {\n              "excludedAppIds": [],\n              "targetedAppIds": []\n            }\n          },\n          "urlTargeting": {\n            "excludedUrls": [],\n            "targetedUrls": []\n          }\n        },\n        "technologyTargeting": {\n          "deviceCapabilityTargeting": {},\n          "deviceCategoryTargeting": {},\n          "operatingSystemTargeting": {\n            "operatingSystemCriteria": {},\n            "operatingSystemVersionCriteria": {}\n          }\n        },\n        "videoTargeting": {\n          "excludedPositionTypes": [],\n          "targetedPositionTypes": []\n        }\n      },\n      "targetingCriterion": [\n        {\n          "exclusions": [\n            {\n              "creativeSizeValue": {\n                "allowedFormats": [],\n                "companionSizes": [\n                  {\n                    "height": 0,\n                    "width": 0\n                  }\n                ],\n                "creativeSizeType": "",\n                "nativeTemplate": "",\n                "size": {},\n                "skippableAdType": ""\n              },\n              "dayPartTargetingValue": {\n                "dayParts": [\n                  {\n                    "dayOfWeek": "",\n                    "endTime": {\n                      "hours": 0,\n                      "minutes": 0,\n                      "nanos": 0,\n                      "seconds": 0\n                    },\n                    "startTime": {}\n                  }\n                ],\n                "timeZoneType": ""\n              },\n              "longValue": "",\n              "stringValue": ""\n            }\n          ],\n          "inclusions": [\n            {}\n          ],\n          "key": ""\n        }\n      ],\n      "updateTime": "",\n      "webPropertyCode": ""\n    }\n  ],\n  "displayName": "",\n  "isRenegotiating": false,\n  "isSetupComplete": false,\n  "lastUpdaterOrCommentorRole": "",\n  "notes": [\n    {\n      "createTime": "",\n      "creatorRole": "",\n      "note": "",\n      "noteId": "",\n      "proposalRevision": ""\n    }\n  ],\n  "originatorRole": "",\n  "privateAuctionId": "",\n  "proposalId": "",\n  "proposalRevision": "",\n  "proposalState": "",\n  "seller": {\n    "accountId": "",\n    "subAccountId": ""\n  },\n  "sellerContacts": [\n    {}\n  ],\n  "termsAndConditions": "",\n  "updateTime": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/proposals
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "billedBuyer": ["accountId": ""],
  "buyer": [],
  "buyerContacts": [
    [
      "email": "",
      "name": ""
    ]
  ],
  "buyerPrivateData": ["referenceId": ""],
  "deals": [
    [
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": [],
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": [
        "creativeFormat": "",
        "creativeSpecifications": [
          [
            "creativeCompanionSizes": [
              [
                "height": "",
                "sizeType": "",
                "width": ""
              ]
            ],
            "creativeSize": []
          ]
        ],
        "skippableAdType": ""
      ],
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": ["dealPauseStatus": [
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        ]],
      "dealTerms": [
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": [
          "amount": [
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          ],
          "pricingType": ""
        ],
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": [
          "fixedPrices": [
            [
              "advertiserIds": [],
              "buyer": [],
              "price": []
            ]
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        ],
        "nonGuaranteedAuctionTerms": [
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [[]]
        ],
        "nonGuaranteedFixedPriceTerms": ["fixedPrices": [[]]],
        "sellerTimeZone": ""
      ],
      "deliveryControl": [
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          [
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          ]
        ]
      ],
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [[]],
      "syndicationProduct": "",
      "targeting": [
        "geoTargeting": [
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        ],
        "inventorySizeTargeting": [
          "excludedInventorySizes": [[]],
          "targetedInventorySizes": [[]]
        ],
        "placementTargeting": [
          "mobileApplicationTargeting": ["firstPartyTargeting": [
              "excludedAppIds": [],
              "targetedAppIds": []
            ]],
          "urlTargeting": [
            "excludedUrls": [],
            "targetedUrls": []
          ]
        ],
        "technologyTargeting": [
          "deviceCapabilityTargeting": [],
          "deviceCategoryTargeting": [],
          "operatingSystemTargeting": [
            "operatingSystemCriteria": [],
            "operatingSystemVersionCriteria": []
          ]
        ],
        "videoTargeting": [
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        ]
      ],
      "targetingCriterion": [
        [
          "exclusions": [
            [
              "creativeSizeValue": [
                "allowedFormats": [],
                "companionSizes": [
                  [
                    "height": 0,
                    "width": 0
                  ]
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": [],
                "skippableAdType": ""
              ],
              "dayPartTargetingValue": [
                "dayParts": [
                  [
                    "dayOfWeek": "",
                    "endTime": [
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    ],
                    "startTime": []
                  ]
                ],
                "timeZoneType": ""
              ],
              "longValue": "",
              "stringValue": ""
            ]
          ],
          "inclusions": [[]],
          "key": ""
        ]
      ],
      "updateTime": "",
      "webPropertyCode": ""
    ]
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    [
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    ]
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": [
    "accountId": "",
    "subAccountId": ""
  ],
  "sellerContacts": [[]],
  "termsAndConditions": "",
  "updateTime": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/proposals")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET adexchangebuyer2.accounts.proposals.get
{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId
QUERY PARAMS

accountId
proposalId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId"

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}}/v2beta1/accounts/:accountId/proposals/:proposalId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId"

	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/v2beta1/accounts/:accountId/proposals/:proposalId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId';
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}}/v2beta1/accounts/:accountId/proposals/:proposalId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId';
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}}/v2beta1/accounts/:accountId/proposals/:proposalId"]
                                                       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}}/v2beta1/accounts/:accountId/proposals/:proposalId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId",
  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}}/v2beta1/accounts/:accountId/proposals/:proposalId');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")

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/v2beta1/accounts/:accountId/proposals/:proposalId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId";

    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}}/v2beta1/accounts/:accountId/proposals/:proposalId
http GET {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")! 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 adexchangebuyer2.accounts.proposals.list
{{baseUrl}}/v2beta1/accounts/:accountId/proposals
QUERY PARAMS

accountId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/proposals");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/proposals")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals"

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}}/v2beta1/accounts/:accountId/proposals"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/proposals");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/proposals"

	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/v2beta1/accounts/:accountId/proposals HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/accounts/:accountId/proposals")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/proposals"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/proposals")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals';
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}}/v2beta1/accounts/:accountId/proposals',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/proposals',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals';
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}}/v2beta1/accounts/:accountId/proposals"]
                                                       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}}/v2beta1/accounts/:accountId/proposals" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/proposals",
  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}}/v2beta1/accounts/:accountId/proposals');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/proposals' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/proposals' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/proposals")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/proposals"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/proposals")

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/v2beta1/accounts/:accountId/proposals') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals";

    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}}/v2beta1/accounts/:accountId/proposals
http GET {{baseUrl}}/v2beta1/accounts/:accountId/proposals
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/proposals
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/proposals")! 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 adexchangebuyer2.accounts.proposals.pause
{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause
QUERY PARAMS

accountId
proposalId
BODY json

{
  "reason": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause");

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  \"reason\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause" {:content-type :json
                                                                                                    :form-params {:reason ""}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"reason\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause"),
    Content = new StringContent("{\n  \"reason\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"reason\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause"

	payload := strings.NewReader("{\n  \"reason\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:pause HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 18

{
  "reason": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"reason\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"reason\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"reason\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause")
  .header("content-type", "application/json")
  .body("{\n  \"reason\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  reason: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause',
  headers: {'content-type': 'application/json'},
  data: {reason: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"reason":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "reason": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"reason\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause")
  .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/v2beta1/accounts/:accountId/proposals/:proposalId:pause',
  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({reason: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause',
  headers: {'content-type': 'application/json'},
  body: {reason: ''},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  reason: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause',
  headers: {'content-type': 'application/json'},
  data: {reason: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"reason":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"reason": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"reason\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'reason' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause', [
  'body' => '{
  "reason": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'reason' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'reason' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause');
$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}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "reason": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "reason": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"reason\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:pause", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause"

payload = { "reason": "" }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause"

payload <- "{\n  \"reason\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause")

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  \"reason\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:pause') do |req|
  req.body = "{\n  \"reason\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause";

    let payload = json!({"reason": ""});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause \
  --header 'content-type: application/json' \
  --data '{
  "reason": ""
}'
echo '{
  "reason": ""
}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "reason": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["reason": ""] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:pause")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST adexchangebuyer2.accounts.proposals.resume
{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume
QUERY PARAMS

accountId
proposalId
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume");

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, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume"),
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume"

	payload := strings.NewReader("{}")

	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/v2beta1/accounts/:accountId/proposals/:proposalId:resume HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume")
  .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/v2beta1/accounts/:accountId/proposals/:proposalId:resume',
  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({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume',
  headers: {'content-type': 'application/json'},
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume');
$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}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:resume", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume"

payload = {}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume"

payload <- "{}"

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}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume")

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 = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId:resume') do |req|
  req.body = "{}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume";

    let payload = 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}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId:resume")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as 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 adexchangebuyer2.accounts.proposals.update
{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId
QUERY PARAMS

accountId
proposalId
BODY json

{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId");

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  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId" {:content-type :json
                                                                                             :form-params {:billedBuyer {:accountId ""}
                                                                                                           :buyer {}
                                                                                                           :buyerContacts [{:email ""
                                                                                                                            :name ""}]
                                                                                                           :buyerPrivateData {:referenceId ""}
                                                                                                           :deals [{:availableEndTime ""
                                                                                                                    :availableStartTime ""
                                                                                                                    :buyerPrivateData {}
                                                                                                                    :createProductId ""
                                                                                                                    :createProductRevision ""
                                                                                                                    :createTime ""
                                                                                                                    :creativePreApprovalPolicy ""
                                                                                                                    :creativeRestrictions {:creativeFormat ""
                                                                                                                                           :creativeSpecifications [{:creativeCompanionSizes [{:height ""
                                                                                                                                                                                               :sizeType ""
                                                                                                                                                                                               :width ""}]
                                                                                                                                                                     :creativeSize {}}]
                                                                                                                                           :skippableAdType ""}
                                                                                                                    :creativeSafeFrameCompatibility ""
                                                                                                                    :dealId ""
                                                                                                                    :dealServingMetadata {:dealPauseStatus {:buyerPauseReason ""
                                                                                                                                                            :firstPausedBy ""
                                                                                                                                                            :hasBuyerPaused false
                                                                                                                                                            :hasSellerPaused false
                                                                                                                                                            :sellerPauseReason ""}}
                                                                                                                    :dealTerms {:brandingType ""
                                                                                                                                :description ""
                                                                                                                                :estimatedGrossSpend {:amount {:currencyCode ""
                                                                                                                                                               :nanos 0
                                                                                                                                                               :units ""}
                                                                                                                                                      :pricingType ""}
                                                                                                                                :estimatedImpressionsPerDay ""
                                                                                                                                :guaranteedFixedPriceTerms {:fixedPrices [{:advertiserIds []
                                                                                                                                                                           :buyer {}
                                                                                                                                                                           :price {}}]
                                                                                                                                                            :guaranteedImpressions ""
                                                                                                                                                            :guaranteedLooks ""
                                                                                                                                                            :impressionCap ""
                                                                                                                                                            :minimumDailyLooks ""
                                                                                                                                                            :percentShareOfVoice ""
                                                                                                                                                            :reservationType ""}
                                                                                                                                :nonGuaranteedAuctionTerms {:autoOptimizePrivateAuction false
                                                                                                                                                            :reservePricesPerBuyer [{}]}
                                                                                                                                :nonGuaranteedFixedPriceTerms {:fixedPrices [{}]}
                                                                                                                                :sellerTimeZone ""}
                                                                                                                    :deliveryControl {:creativeBlockingLevel ""
                                                                                                                                      :deliveryRateType ""
                                                                                                                                      :frequencyCaps [{:maxImpressions 0
                                                                                                                                                       :numTimeUnits 0
                                                                                                                                                       :timeUnitType ""}]}
                                                                                                                    :description ""
                                                                                                                    :displayName ""
                                                                                                                    :externalDealId ""
                                                                                                                    :isSetupComplete false
                                                                                                                    :programmaticCreativeSource ""
                                                                                                                    :proposalId ""
                                                                                                                    :sellerContacts [{}]
                                                                                                                    :syndicationProduct ""
                                                                                                                    :targeting {:geoTargeting {:excludedCriteriaIds []
                                                                                                                                               :targetedCriteriaIds []}
                                                                                                                                :inventorySizeTargeting {:excludedInventorySizes [{}]
                                                                                                                                                         :targetedInventorySizes [{}]}
                                                                                                                                :placementTargeting {:mobileApplicationTargeting {:firstPartyTargeting {:excludedAppIds []
                                                                                                                                                                                                        :targetedAppIds []}}
                                                                                                                                                     :urlTargeting {:excludedUrls []
                                                                                                                                                                    :targetedUrls []}}
                                                                                                                                :technologyTargeting {:deviceCapabilityTargeting {}
                                                                                                                                                      :deviceCategoryTargeting {}
                                                                                                                                                      :operatingSystemTargeting {:operatingSystemCriteria {}
                                                                                                                                                                                 :operatingSystemVersionCriteria {}}}
                                                                                                                                :videoTargeting {:excludedPositionTypes []
                                                                                                                                                 :targetedPositionTypes []}}
                                                                                                                    :targetingCriterion [{:exclusions [{:creativeSizeValue {:allowedFormats []
                                                                                                                                                                            :companionSizes [{:height 0
                                                                                                                                                                                              :width 0}]
                                                                                                                                                                            :creativeSizeType ""
                                                                                                                                                                            :nativeTemplate ""
                                                                                                                                                                            :size {}
                                                                                                                                                                            :skippableAdType ""}
                                                                                                                                                        :dayPartTargetingValue {:dayParts [{:dayOfWeek ""
                                                                                                                                                                                            :endTime {:hours 0
                                                                                                                                                                                                      :minutes 0
                                                                                                                                                                                                      :nanos 0
                                                                                                                                                                                                      :seconds 0}
                                                                                                                                                                                            :startTime {}}]
                                                                                                                                                                                :timeZoneType ""}
                                                                                                                                                        :longValue ""
                                                                                                                                                        :stringValue ""}]
                                                                                                                                          :inclusions [{}]
                                                                                                                                          :key ""}]
                                                                                                                    :updateTime ""
                                                                                                                    :webPropertyCode ""}]
                                                                                                           :displayName ""
                                                                                                           :isRenegotiating false
                                                                                                           :isSetupComplete false
                                                                                                           :lastUpdaterOrCommentorRole ""
                                                                                                           :notes [{:createTime ""
                                                                                                                    :creatorRole ""
                                                                                                                    :note ""
                                                                                                                    :noteId ""
                                                                                                                    :proposalRevision ""}]
                                                                                                           :originatorRole ""
                                                                                                           :privateAuctionId ""
                                                                                                           :proposalId ""
                                                                                                           :proposalRevision ""
                                                                                                           :proposalState ""
                                                                                                           :seller {:accountId ""
                                                                                                                    :subAccountId ""}
                                                                                                           :sellerContacts [{}]
                                                                                                           :termsAndConditions ""
                                                                                                           :updateTime ""}})
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\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}}/v2beta1/accounts/:accountId/proposals/:proposalId"),
    Content = new StringContent("{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId"

	payload := strings.NewReader("{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\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/v2beta1/accounts/:accountId/proposals/:proposalId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 5376

{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")
  .header("content-type", "application/json")
  .body("{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  billedBuyer: {
    accountId: ''
  },
  buyer: {},
  buyerContacts: [
    {
      email: '',
      name: ''
    }
  ],
  buyerPrivateData: {
    referenceId: ''
  },
  deals: [
    {
      availableEndTime: '',
      availableStartTime: '',
      buyerPrivateData: {},
      createProductId: '',
      createProductRevision: '',
      createTime: '',
      creativePreApprovalPolicy: '',
      creativeRestrictions: {
        creativeFormat: '',
        creativeSpecifications: [
          {
            creativeCompanionSizes: [
              {
                height: '',
                sizeType: '',
                width: ''
              }
            ],
            creativeSize: {}
          }
        ],
        skippableAdType: ''
      },
      creativeSafeFrameCompatibility: '',
      dealId: '',
      dealServingMetadata: {
        dealPauseStatus: {
          buyerPauseReason: '',
          firstPausedBy: '',
          hasBuyerPaused: false,
          hasSellerPaused: false,
          sellerPauseReason: ''
        }
      },
      dealTerms: {
        brandingType: '',
        description: '',
        estimatedGrossSpend: {
          amount: {
            currencyCode: '',
            nanos: 0,
            units: ''
          },
          pricingType: ''
        },
        estimatedImpressionsPerDay: '',
        guaranteedFixedPriceTerms: {
          fixedPrices: [
            {
              advertiserIds: [],
              buyer: {},
              price: {}
            }
          ],
          guaranteedImpressions: '',
          guaranteedLooks: '',
          impressionCap: '',
          minimumDailyLooks: '',
          percentShareOfVoice: '',
          reservationType: ''
        },
        nonGuaranteedAuctionTerms: {
          autoOptimizePrivateAuction: false,
          reservePricesPerBuyer: [
            {}
          ]
        },
        nonGuaranteedFixedPriceTerms: {
          fixedPrices: [
            {}
          ]
        },
        sellerTimeZone: ''
      },
      deliveryControl: {
        creativeBlockingLevel: '',
        deliveryRateType: '',
        frequencyCaps: [
          {
            maxImpressions: 0,
            numTimeUnits: 0,
            timeUnitType: ''
          }
        ]
      },
      description: '',
      displayName: '',
      externalDealId: '',
      isSetupComplete: false,
      programmaticCreativeSource: '',
      proposalId: '',
      sellerContacts: [
        {}
      ],
      syndicationProduct: '',
      targeting: {
        geoTargeting: {
          excludedCriteriaIds: [],
          targetedCriteriaIds: []
        },
        inventorySizeTargeting: {
          excludedInventorySizes: [
            {}
          ],
          targetedInventorySizes: [
            {}
          ]
        },
        placementTargeting: {
          mobileApplicationTargeting: {
            firstPartyTargeting: {
              excludedAppIds: [],
              targetedAppIds: []
            }
          },
          urlTargeting: {
            excludedUrls: [],
            targetedUrls: []
          }
        },
        technologyTargeting: {
          deviceCapabilityTargeting: {},
          deviceCategoryTargeting: {},
          operatingSystemTargeting: {
            operatingSystemCriteria: {},
            operatingSystemVersionCriteria: {}
          }
        },
        videoTargeting: {
          excludedPositionTypes: [],
          targetedPositionTypes: []
        }
      },
      targetingCriterion: [
        {
          exclusions: [
            {
              creativeSizeValue: {
                allowedFormats: [],
                companionSizes: [
                  {
                    height: 0,
                    width: 0
                  }
                ],
                creativeSizeType: '',
                nativeTemplate: '',
                size: {},
                skippableAdType: ''
              },
              dayPartTargetingValue: {
                dayParts: [
                  {
                    dayOfWeek: '',
                    endTime: {
                      hours: 0,
                      minutes: 0,
                      nanos: 0,
                      seconds: 0
                    },
                    startTime: {}
                  }
                ],
                timeZoneType: ''
              },
              longValue: '',
              stringValue: ''
            }
          ],
          inclusions: [
            {}
          ],
          key: ''
        }
      ],
      updateTime: '',
      webPropertyCode: ''
    }
  ],
  displayName: '',
  isRenegotiating: false,
  isSetupComplete: false,
  lastUpdaterOrCommentorRole: '',
  notes: [
    {
      createTime: '',
      creatorRole: '',
      note: '',
      noteId: '',
      proposalRevision: ''
    }
  ],
  originatorRole: '',
  privateAuctionId: '',
  proposalId: '',
  proposalRevision: '',
  proposalState: '',
  seller: {
    accountId: '',
    subAccountId: ''
  },
  sellerContacts: [
    {}
  ],
  termsAndConditions: '',
  updateTime: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId',
  headers: {'content-type': 'application/json'},
  data: {
    billedBuyer: {accountId: ''},
    buyer: {},
    buyerContacts: [{email: '', name: ''}],
    buyerPrivateData: {referenceId: ''},
    deals: [
      {
        availableEndTime: '',
        availableStartTime: '',
        buyerPrivateData: {},
        createProductId: '',
        createProductRevision: '',
        createTime: '',
        creativePreApprovalPolicy: '',
        creativeRestrictions: {
          creativeFormat: '',
          creativeSpecifications: [
            {
              creativeCompanionSizes: [{height: '', sizeType: '', width: ''}],
              creativeSize: {}
            }
          ],
          skippableAdType: ''
        },
        creativeSafeFrameCompatibility: '',
        dealId: '',
        dealServingMetadata: {
          dealPauseStatus: {
            buyerPauseReason: '',
            firstPausedBy: '',
            hasBuyerPaused: false,
            hasSellerPaused: false,
            sellerPauseReason: ''
          }
        },
        dealTerms: {
          brandingType: '',
          description: '',
          estimatedGrossSpend: {amount: {currencyCode: '', nanos: 0, units: ''}, pricingType: ''},
          estimatedImpressionsPerDay: '',
          guaranteedFixedPriceTerms: {
            fixedPrices: [{advertiserIds: [], buyer: {}, price: {}}],
            guaranteedImpressions: '',
            guaranteedLooks: '',
            impressionCap: '',
            minimumDailyLooks: '',
            percentShareOfVoice: '',
            reservationType: ''
          },
          nonGuaranteedAuctionTerms: {autoOptimizePrivateAuction: false, reservePricesPerBuyer: [{}]},
          nonGuaranteedFixedPriceTerms: {fixedPrices: [{}]},
          sellerTimeZone: ''
        },
        deliveryControl: {
          creativeBlockingLevel: '',
          deliveryRateType: '',
          frequencyCaps: [{maxImpressions: 0, numTimeUnits: 0, timeUnitType: ''}]
        },
        description: '',
        displayName: '',
        externalDealId: '',
        isSetupComplete: false,
        programmaticCreativeSource: '',
        proposalId: '',
        sellerContacts: [{}],
        syndicationProduct: '',
        targeting: {
          geoTargeting: {excludedCriteriaIds: [], targetedCriteriaIds: []},
          inventorySizeTargeting: {excludedInventorySizes: [{}], targetedInventorySizes: [{}]},
          placementTargeting: {
            mobileApplicationTargeting: {firstPartyTargeting: {excludedAppIds: [], targetedAppIds: []}},
            urlTargeting: {excludedUrls: [], targetedUrls: []}
          },
          technologyTargeting: {
            deviceCapabilityTargeting: {},
            deviceCategoryTargeting: {},
            operatingSystemTargeting: {operatingSystemCriteria: {}, operatingSystemVersionCriteria: {}}
          },
          videoTargeting: {excludedPositionTypes: [], targetedPositionTypes: []}
        },
        targetingCriterion: [
          {
            exclusions: [
              {
                creativeSizeValue: {
                  allowedFormats: [],
                  companionSizes: [{height: 0, width: 0}],
                  creativeSizeType: '',
                  nativeTemplate: '',
                  size: {},
                  skippableAdType: ''
                },
                dayPartTargetingValue: {
                  dayParts: [
                    {
                      dayOfWeek: '',
                      endTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
                      startTime: {}
                    }
                  ],
                  timeZoneType: ''
                },
                longValue: '',
                stringValue: ''
              }
            ],
            inclusions: [{}],
            key: ''
          }
        ],
        updateTime: '',
        webPropertyCode: ''
      }
    ],
    displayName: '',
    isRenegotiating: false,
    isSetupComplete: false,
    lastUpdaterOrCommentorRole: '',
    notes: [{createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}],
    originatorRole: '',
    privateAuctionId: '',
    proposalId: '',
    proposalRevision: '',
    proposalState: '',
    seller: {accountId: '', subAccountId: ''},
    sellerContacts: [{}],
    termsAndConditions: '',
    updateTime: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"billedBuyer":{"accountId":""},"buyer":{},"buyerContacts":[{"email":"","name":""}],"buyerPrivateData":{"referenceId":""},"deals":[{"availableEndTime":"","availableStartTime":"","buyerPrivateData":{},"createProductId":"","createProductRevision":"","createTime":"","creativePreApprovalPolicy":"","creativeRestrictions":{"creativeFormat":"","creativeSpecifications":[{"creativeCompanionSizes":[{"height":"","sizeType":"","width":""}],"creativeSize":{}}],"skippableAdType":""},"creativeSafeFrameCompatibility":"","dealId":"","dealServingMetadata":{"dealPauseStatus":{"buyerPauseReason":"","firstPausedBy":"","hasBuyerPaused":false,"hasSellerPaused":false,"sellerPauseReason":""}},"dealTerms":{"brandingType":"","description":"","estimatedGrossSpend":{"amount":{"currencyCode":"","nanos":0,"units":""},"pricingType":""},"estimatedImpressionsPerDay":"","guaranteedFixedPriceTerms":{"fixedPrices":[{"advertiserIds":[],"buyer":{},"price":{}}],"guaranteedImpressions":"","guaranteedLooks":"","impressionCap":"","minimumDailyLooks":"","percentShareOfVoice":"","reservationType":""},"nonGuaranteedAuctionTerms":{"autoOptimizePrivateAuction":false,"reservePricesPerBuyer":[{}]},"nonGuaranteedFixedPriceTerms":{"fixedPrices":[{}]},"sellerTimeZone":""},"deliveryControl":{"creativeBlockingLevel":"","deliveryRateType":"","frequencyCaps":[{"maxImpressions":0,"numTimeUnits":0,"timeUnitType":""}]},"description":"","displayName":"","externalDealId":"","isSetupComplete":false,"programmaticCreativeSource":"","proposalId":"","sellerContacts":[{}],"syndicationProduct":"","targeting":{"geoTargeting":{"excludedCriteriaIds":[],"targetedCriteriaIds":[]},"inventorySizeTargeting":{"excludedInventorySizes":[{}],"targetedInventorySizes":[{}]},"placementTargeting":{"mobileApplicationTargeting":{"firstPartyTargeting":{"excludedAppIds":[],"targetedAppIds":[]}},"urlTargeting":{"excludedUrls":[],"targetedUrls":[]}},"technologyTargeting":{"deviceCapabilityTargeting":{},"deviceCategoryTargeting":{},"operatingSystemTargeting":{"operatingSystemCriteria":{},"operatingSystemVersionCriteria":{}}},"videoTargeting":{"excludedPositionTypes":[],"targetedPositionTypes":[]}},"targetingCriterion":[{"exclusions":[{"creativeSizeValue":{"allowedFormats":[],"companionSizes":[{"height":0,"width":0}],"creativeSizeType":"","nativeTemplate":"","size":{},"skippableAdType":""},"dayPartTargetingValue":{"dayParts":[{"dayOfWeek":"","endTime":{"hours":0,"minutes":0,"nanos":0,"seconds":0},"startTime":{}}],"timeZoneType":""},"longValue":"","stringValue":""}],"inclusions":[{}],"key":""}],"updateTime":"","webPropertyCode":""}],"displayName":"","isRenegotiating":false,"isSetupComplete":false,"lastUpdaterOrCommentorRole":"","notes":[{"createTime":"","creatorRole":"","note":"","noteId":"","proposalRevision":""}],"originatorRole":"","privateAuctionId":"","proposalId":"","proposalRevision":"","proposalState":"","seller":{"accountId":"","subAccountId":""},"sellerContacts":[{}],"termsAndConditions":"","updateTime":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "billedBuyer": {\n    "accountId": ""\n  },\n  "buyer": {},\n  "buyerContacts": [\n    {\n      "email": "",\n      "name": ""\n    }\n  ],\n  "buyerPrivateData": {\n    "referenceId": ""\n  },\n  "deals": [\n    {\n      "availableEndTime": "",\n      "availableStartTime": "",\n      "buyerPrivateData": {},\n      "createProductId": "",\n      "createProductRevision": "",\n      "createTime": "",\n      "creativePreApprovalPolicy": "",\n      "creativeRestrictions": {\n        "creativeFormat": "",\n        "creativeSpecifications": [\n          {\n            "creativeCompanionSizes": [\n              {\n                "height": "",\n                "sizeType": "",\n                "width": ""\n              }\n            ],\n            "creativeSize": {}\n          }\n        ],\n        "skippableAdType": ""\n      },\n      "creativeSafeFrameCompatibility": "",\n      "dealId": "",\n      "dealServingMetadata": {\n        "dealPauseStatus": {\n          "buyerPauseReason": "",\n          "firstPausedBy": "",\n          "hasBuyerPaused": false,\n          "hasSellerPaused": false,\n          "sellerPauseReason": ""\n        }\n      },\n      "dealTerms": {\n        "brandingType": "",\n        "description": "",\n        "estimatedGrossSpend": {\n          "amount": {\n            "currencyCode": "",\n            "nanos": 0,\n            "units": ""\n          },\n          "pricingType": ""\n        },\n        "estimatedImpressionsPerDay": "",\n        "guaranteedFixedPriceTerms": {\n          "fixedPrices": [\n            {\n              "advertiserIds": [],\n              "buyer": {},\n              "price": {}\n            }\n          ],\n          "guaranteedImpressions": "",\n          "guaranteedLooks": "",\n          "impressionCap": "",\n          "minimumDailyLooks": "",\n          "percentShareOfVoice": "",\n          "reservationType": ""\n        },\n        "nonGuaranteedAuctionTerms": {\n          "autoOptimizePrivateAuction": false,\n          "reservePricesPerBuyer": [\n            {}\n          ]\n        },\n        "nonGuaranteedFixedPriceTerms": {\n          "fixedPrices": [\n            {}\n          ]\n        },\n        "sellerTimeZone": ""\n      },\n      "deliveryControl": {\n        "creativeBlockingLevel": "",\n        "deliveryRateType": "",\n        "frequencyCaps": [\n          {\n            "maxImpressions": 0,\n            "numTimeUnits": 0,\n            "timeUnitType": ""\n          }\n        ]\n      },\n      "description": "",\n      "displayName": "",\n      "externalDealId": "",\n      "isSetupComplete": false,\n      "programmaticCreativeSource": "",\n      "proposalId": "",\n      "sellerContacts": [\n        {}\n      ],\n      "syndicationProduct": "",\n      "targeting": {\n        "geoTargeting": {\n          "excludedCriteriaIds": [],\n          "targetedCriteriaIds": []\n        },\n        "inventorySizeTargeting": {\n          "excludedInventorySizes": [\n            {}\n          ],\n          "targetedInventorySizes": [\n            {}\n          ]\n        },\n        "placementTargeting": {\n          "mobileApplicationTargeting": {\n            "firstPartyTargeting": {\n              "excludedAppIds": [],\n              "targetedAppIds": []\n            }\n          },\n          "urlTargeting": {\n            "excludedUrls": [],\n            "targetedUrls": []\n          }\n        },\n        "technologyTargeting": {\n          "deviceCapabilityTargeting": {},\n          "deviceCategoryTargeting": {},\n          "operatingSystemTargeting": {\n            "operatingSystemCriteria": {},\n            "operatingSystemVersionCriteria": {}\n          }\n        },\n        "videoTargeting": {\n          "excludedPositionTypes": [],\n          "targetedPositionTypes": []\n        }\n      },\n      "targetingCriterion": [\n        {\n          "exclusions": [\n            {\n              "creativeSizeValue": {\n                "allowedFormats": [],\n                "companionSizes": [\n                  {\n                    "height": 0,\n                    "width": 0\n                  }\n                ],\n                "creativeSizeType": "",\n                "nativeTemplate": "",\n                "size": {},\n                "skippableAdType": ""\n              },\n              "dayPartTargetingValue": {\n                "dayParts": [\n                  {\n                    "dayOfWeek": "",\n                    "endTime": {\n                      "hours": 0,\n                      "minutes": 0,\n                      "nanos": 0,\n                      "seconds": 0\n                    },\n                    "startTime": {}\n                  }\n                ],\n                "timeZoneType": ""\n              },\n              "longValue": "",\n              "stringValue": ""\n            }\n          ],\n          "inclusions": [\n            {}\n          ],\n          "key": ""\n        }\n      ],\n      "updateTime": "",\n      "webPropertyCode": ""\n    }\n  ],\n  "displayName": "",\n  "isRenegotiating": false,\n  "isSetupComplete": false,\n  "lastUpdaterOrCommentorRole": "",\n  "notes": [\n    {\n      "createTime": "",\n      "creatorRole": "",\n      "note": "",\n      "noteId": "",\n      "proposalRevision": ""\n    }\n  ],\n  "originatorRole": "",\n  "privateAuctionId": "",\n  "proposalId": "",\n  "proposalRevision": "",\n  "proposalState": "",\n  "seller": {\n    "accountId": "",\n    "subAccountId": ""\n  },\n  "sellerContacts": [\n    {}\n  ],\n  "termsAndConditions": "",\n  "updateTime": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")
  .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/v2beta1/accounts/:accountId/proposals/:proposalId',
  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({
  billedBuyer: {accountId: ''},
  buyer: {},
  buyerContacts: [{email: '', name: ''}],
  buyerPrivateData: {referenceId: ''},
  deals: [
    {
      availableEndTime: '',
      availableStartTime: '',
      buyerPrivateData: {},
      createProductId: '',
      createProductRevision: '',
      createTime: '',
      creativePreApprovalPolicy: '',
      creativeRestrictions: {
        creativeFormat: '',
        creativeSpecifications: [
          {
            creativeCompanionSizes: [{height: '', sizeType: '', width: ''}],
            creativeSize: {}
          }
        ],
        skippableAdType: ''
      },
      creativeSafeFrameCompatibility: '',
      dealId: '',
      dealServingMetadata: {
        dealPauseStatus: {
          buyerPauseReason: '',
          firstPausedBy: '',
          hasBuyerPaused: false,
          hasSellerPaused: false,
          sellerPauseReason: ''
        }
      },
      dealTerms: {
        brandingType: '',
        description: '',
        estimatedGrossSpend: {amount: {currencyCode: '', nanos: 0, units: ''}, pricingType: ''},
        estimatedImpressionsPerDay: '',
        guaranteedFixedPriceTerms: {
          fixedPrices: [{advertiserIds: [], buyer: {}, price: {}}],
          guaranteedImpressions: '',
          guaranteedLooks: '',
          impressionCap: '',
          minimumDailyLooks: '',
          percentShareOfVoice: '',
          reservationType: ''
        },
        nonGuaranteedAuctionTerms: {autoOptimizePrivateAuction: false, reservePricesPerBuyer: [{}]},
        nonGuaranteedFixedPriceTerms: {fixedPrices: [{}]},
        sellerTimeZone: ''
      },
      deliveryControl: {
        creativeBlockingLevel: '',
        deliveryRateType: '',
        frequencyCaps: [{maxImpressions: 0, numTimeUnits: 0, timeUnitType: ''}]
      },
      description: '',
      displayName: '',
      externalDealId: '',
      isSetupComplete: false,
      programmaticCreativeSource: '',
      proposalId: '',
      sellerContacts: [{}],
      syndicationProduct: '',
      targeting: {
        geoTargeting: {excludedCriteriaIds: [], targetedCriteriaIds: []},
        inventorySizeTargeting: {excludedInventorySizes: [{}], targetedInventorySizes: [{}]},
        placementTargeting: {
          mobileApplicationTargeting: {firstPartyTargeting: {excludedAppIds: [], targetedAppIds: []}},
          urlTargeting: {excludedUrls: [], targetedUrls: []}
        },
        technologyTargeting: {
          deviceCapabilityTargeting: {},
          deviceCategoryTargeting: {},
          operatingSystemTargeting: {operatingSystemCriteria: {}, operatingSystemVersionCriteria: {}}
        },
        videoTargeting: {excludedPositionTypes: [], targetedPositionTypes: []}
      },
      targetingCriterion: [
        {
          exclusions: [
            {
              creativeSizeValue: {
                allowedFormats: [],
                companionSizes: [{height: 0, width: 0}],
                creativeSizeType: '',
                nativeTemplate: '',
                size: {},
                skippableAdType: ''
              },
              dayPartTargetingValue: {
                dayParts: [
                  {
                    dayOfWeek: '',
                    endTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
                    startTime: {}
                  }
                ],
                timeZoneType: ''
              },
              longValue: '',
              stringValue: ''
            }
          ],
          inclusions: [{}],
          key: ''
        }
      ],
      updateTime: '',
      webPropertyCode: ''
    }
  ],
  displayName: '',
  isRenegotiating: false,
  isSetupComplete: false,
  lastUpdaterOrCommentorRole: '',
  notes: [{createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}],
  originatorRole: '',
  privateAuctionId: '',
  proposalId: '',
  proposalRevision: '',
  proposalState: '',
  seller: {accountId: '', subAccountId: ''},
  sellerContacts: [{}],
  termsAndConditions: '',
  updateTime: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId',
  headers: {'content-type': 'application/json'},
  body: {
    billedBuyer: {accountId: ''},
    buyer: {},
    buyerContacts: [{email: '', name: ''}],
    buyerPrivateData: {referenceId: ''},
    deals: [
      {
        availableEndTime: '',
        availableStartTime: '',
        buyerPrivateData: {},
        createProductId: '',
        createProductRevision: '',
        createTime: '',
        creativePreApprovalPolicy: '',
        creativeRestrictions: {
          creativeFormat: '',
          creativeSpecifications: [
            {
              creativeCompanionSizes: [{height: '', sizeType: '', width: ''}],
              creativeSize: {}
            }
          ],
          skippableAdType: ''
        },
        creativeSafeFrameCompatibility: '',
        dealId: '',
        dealServingMetadata: {
          dealPauseStatus: {
            buyerPauseReason: '',
            firstPausedBy: '',
            hasBuyerPaused: false,
            hasSellerPaused: false,
            sellerPauseReason: ''
          }
        },
        dealTerms: {
          brandingType: '',
          description: '',
          estimatedGrossSpend: {amount: {currencyCode: '', nanos: 0, units: ''}, pricingType: ''},
          estimatedImpressionsPerDay: '',
          guaranteedFixedPriceTerms: {
            fixedPrices: [{advertiserIds: [], buyer: {}, price: {}}],
            guaranteedImpressions: '',
            guaranteedLooks: '',
            impressionCap: '',
            minimumDailyLooks: '',
            percentShareOfVoice: '',
            reservationType: ''
          },
          nonGuaranteedAuctionTerms: {autoOptimizePrivateAuction: false, reservePricesPerBuyer: [{}]},
          nonGuaranteedFixedPriceTerms: {fixedPrices: [{}]},
          sellerTimeZone: ''
        },
        deliveryControl: {
          creativeBlockingLevel: '',
          deliveryRateType: '',
          frequencyCaps: [{maxImpressions: 0, numTimeUnits: 0, timeUnitType: ''}]
        },
        description: '',
        displayName: '',
        externalDealId: '',
        isSetupComplete: false,
        programmaticCreativeSource: '',
        proposalId: '',
        sellerContacts: [{}],
        syndicationProduct: '',
        targeting: {
          geoTargeting: {excludedCriteriaIds: [], targetedCriteriaIds: []},
          inventorySizeTargeting: {excludedInventorySizes: [{}], targetedInventorySizes: [{}]},
          placementTargeting: {
            mobileApplicationTargeting: {firstPartyTargeting: {excludedAppIds: [], targetedAppIds: []}},
            urlTargeting: {excludedUrls: [], targetedUrls: []}
          },
          technologyTargeting: {
            deviceCapabilityTargeting: {},
            deviceCategoryTargeting: {},
            operatingSystemTargeting: {operatingSystemCriteria: {}, operatingSystemVersionCriteria: {}}
          },
          videoTargeting: {excludedPositionTypes: [], targetedPositionTypes: []}
        },
        targetingCriterion: [
          {
            exclusions: [
              {
                creativeSizeValue: {
                  allowedFormats: [],
                  companionSizes: [{height: 0, width: 0}],
                  creativeSizeType: '',
                  nativeTemplate: '',
                  size: {},
                  skippableAdType: ''
                },
                dayPartTargetingValue: {
                  dayParts: [
                    {
                      dayOfWeek: '',
                      endTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
                      startTime: {}
                    }
                  ],
                  timeZoneType: ''
                },
                longValue: '',
                stringValue: ''
              }
            ],
            inclusions: [{}],
            key: ''
          }
        ],
        updateTime: '',
        webPropertyCode: ''
      }
    ],
    displayName: '',
    isRenegotiating: false,
    isSetupComplete: false,
    lastUpdaterOrCommentorRole: '',
    notes: [{createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}],
    originatorRole: '',
    privateAuctionId: '',
    proposalId: '',
    proposalRevision: '',
    proposalState: '',
    seller: {accountId: '', subAccountId: ''},
    sellerContacts: [{}],
    termsAndConditions: '',
    updateTime: ''
  },
  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}}/v2beta1/accounts/:accountId/proposals/:proposalId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  billedBuyer: {
    accountId: ''
  },
  buyer: {},
  buyerContacts: [
    {
      email: '',
      name: ''
    }
  ],
  buyerPrivateData: {
    referenceId: ''
  },
  deals: [
    {
      availableEndTime: '',
      availableStartTime: '',
      buyerPrivateData: {},
      createProductId: '',
      createProductRevision: '',
      createTime: '',
      creativePreApprovalPolicy: '',
      creativeRestrictions: {
        creativeFormat: '',
        creativeSpecifications: [
          {
            creativeCompanionSizes: [
              {
                height: '',
                sizeType: '',
                width: ''
              }
            ],
            creativeSize: {}
          }
        ],
        skippableAdType: ''
      },
      creativeSafeFrameCompatibility: '',
      dealId: '',
      dealServingMetadata: {
        dealPauseStatus: {
          buyerPauseReason: '',
          firstPausedBy: '',
          hasBuyerPaused: false,
          hasSellerPaused: false,
          sellerPauseReason: ''
        }
      },
      dealTerms: {
        brandingType: '',
        description: '',
        estimatedGrossSpend: {
          amount: {
            currencyCode: '',
            nanos: 0,
            units: ''
          },
          pricingType: ''
        },
        estimatedImpressionsPerDay: '',
        guaranteedFixedPriceTerms: {
          fixedPrices: [
            {
              advertiserIds: [],
              buyer: {},
              price: {}
            }
          ],
          guaranteedImpressions: '',
          guaranteedLooks: '',
          impressionCap: '',
          minimumDailyLooks: '',
          percentShareOfVoice: '',
          reservationType: ''
        },
        nonGuaranteedAuctionTerms: {
          autoOptimizePrivateAuction: false,
          reservePricesPerBuyer: [
            {}
          ]
        },
        nonGuaranteedFixedPriceTerms: {
          fixedPrices: [
            {}
          ]
        },
        sellerTimeZone: ''
      },
      deliveryControl: {
        creativeBlockingLevel: '',
        deliveryRateType: '',
        frequencyCaps: [
          {
            maxImpressions: 0,
            numTimeUnits: 0,
            timeUnitType: ''
          }
        ]
      },
      description: '',
      displayName: '',
      externalDealId: '',
      isSetupComplete: false,
      programmaticCreativeSource: '',
      proposalId: '',
      sellerContacts: [
        {}
      ],
      syndicationProduct: '',
      targeting: {
        geoTargeting: {
          excludedCriteriaIds: [],
          targetedCriteriaIds: []
        },
        inventorySizeTargeting: {
          excludedInventorySizes: [
            {}
          ],
          targetedInventorySizes: [
            {}
          ]
        },
        placementTargeting: {
          mobileApplicationTargeting: {
            firstPartyTargeting: {
              excludedAppIds: [],
              targetedAppIds: []
            }
          },
          urlTargeting: {
            excludedUrls: [],
            targetedUrls: []
          }
        },
        technologyTargeting: {
          deviceCapabilityTargeting: {},
          deviceCategoryTargeting: {},
          operatingSystemTargeting: {
            operatingSystemCriteria: {},
            operatingSystemVersionCriteria: {}
          }
        },
        videoTargeting: {
          excludedPositionTypes: [],
          targetedPositionTypes: []
        }
      },
      targetingCriterion: [
        {
          exclusions: [
            {
              creativeSizeValue: {
                allowedFormats: [],
                companionSizes: [
                  {
                    height: 0,
                    width: 0
                  }
                ],
                creativeSizeType: '',
                nativeTemplate: '',
                size: {},
                skippableAdType: ''
              },
              dayPartTargetingValue: {
                dayParts: [
                  {
                    dayOfWeek: '',
                    endTime: {
                      hours: 0,
                      minutes: 0,
                      nanos: 0,
                      seconds: 0
                    },
                    startTime: {}
                  }
                ],
                timeZoneType: ''
              },
              longValue: '',
              stringValue: ''
            }
          ],
          inclusions: [
            {}
          ],
          key: ''
        }
      ],
      updateTime: '',
      webPropertyCode: ''
    }
  ],
  displayName: '',
  isRenegotiating: false,
  isSetupComplete: false,
  lastUpdaterOrCommentorRole: '',
  notes: [
    {
      createTime: '',
      creatorRole: '',
      note: '',
      noteId: '',
      proposalRevision: ''
    }
  ],
  originatorRole: '',
  privateAuctionId: '',
  proposalId: '',
  proposalRevision: '',
  proposalState: '',
  seller: {
    accountId: '',
    subAccountId: ''
  },
  sellerContacts: [
    {}
  ],
  termsAndConditions: '',
  updateTime: ''
});

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}}/v2beta1/accounts/:accountId/proposals/:proposalId',
  headers: {'content-type': 'application/json'},
  data: {
    billedBuyer: {accountId: ''},
    buyer: {},
    buyerContacts: [{email: '', name: ''}],
    buyerPrivateData: {referenceId: ''},
    deals: [
      {
        availableEndTime: '',
        availableStartTime: '',
        buyerPrivateData: {},
        createProductId: '',
        createProductRevision: '',
        createTime: '',
        creativePreApprovalPolicy: '',
        creativeRestrictions: {
          creativeFormat: '',
          creativeSpecifications: [
            {
              creativeCompanionSizes: [{height: '', sizeType: '', width: ''}],
              creativeSize: {}
            }
          ],
          skippableAdType: ''
        },
        creativeSafeFrameCompatibility: '',
        dealId: '',
        dealServingMetadata: {
          dealPauseStatus: {
            buyerPauseReason: '',
            firstPausedBy: '',
            hasBuyerPaused: false,
            hasSellerPaused: false,
            sellerPauseReason: ''
          }
        },
        dealTerms: {
          brandingType: '',
          description: '',
          estimatedGrossSpend: {amount: {currencyCode: '', nanos: 0, units: ''}, pricingType: ''},
          estimatedImpressionsPerDay: '',
          guaranteedFixedPriceTerms: {
            fixedPrices: [{advertiserIds: [], buyer: {}, price: {}}],
            guaranteedImpressions: '',
            guaranteedLooks: '',
            impressionCap: '',
            minimumDailyLooks: '',
            percentShareOfVoice: '',
            reservationType: ''
          },
          nonGuaranteedAuctionTerms: {autoOptimizePrivateAuction: false, reservePricesPerBuyer: [{}]},
          nonGuaranteedFixedPriceTerms: {fixedPrices: [{}]},
          sellerTimeZone: ''
        },
        deliveryControl: {
          creativeBlockingLevel: '',
          deliveryRateType: '',
          frequencyCaps: [{maxImpressions: 0, numTimeUnits: 0, timeUnitType: ''}]
        },
        description: '',
        displayName: '',
        externalDealId: '',
        isSetupComplete: false,
        programmaticCreativeSource: '',
        proposalId: '',
        sellerContacts: [{}],
        syndicationProduct: '',
        targeting: {
          geoTargeting: {excludedCriteriaIds: [], targetedCriteriaIds: []},
          inventorySizeTargeting: {excludedInventorySizes: [{}], targetedInventorySizes: [{}]},
          placementTargeting: {
            mobileApplicationTargeting: {firstPartyTargeting: {excludedAppIds: [], targetedAppIds: []}},
            urlTargeting: {excludedUrls: [], targetedUrls: []}
          },
          technologyTargeting: {
            deviceCapabilityTargeting: {},
            deviceCategoryTargeting: {},
            operatingSystemTargeting: {operatingSystemCriteria: {}, operatingSystemVersionCriteria: {}}
          },
          videoTargeting: {excludedPositionTypes: [], targetedPositionTypes: []}
        },
        targetingCriterion: [
          {
            exclusions: [
              {
                creativeSizeValue: {
                  allowedFormats: [],
                  companionSizes: [{height: 0, width: 0}],
                  creativeSizeType: '',
                  nativeTemplate: '',
                  size: {},
                  skippableAdType: ''
                },
                dayPartTargetingValue: {
                  dayParts: [
                    {
                      dayOfWeek: '',
                      endTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
                      startTime: {}
                    }
                  ],
                  timeZoneType: ''
                },
                longValue: '',
                stringValue: ''
              }
            ],
            inclusions: [{}],
            key: ''
          }
        ],
        updateTime: '',
        webPropertyCode: ''
      }
    ],
    displayName: '',
    isRenegotiating: false,
    isSetupComplete: false,
    lastUpdaterOrCommentorRole: '',
    notes: [{createTime: '', creatorRole: '', note: '', noteId: '', proposalRevision: ''}],
    originatorRole: '',
    privateAuctionId: '',
    proposalId: '',
    proposalRevision: '',
    proposalState: '',
    seller: {accountId: '', subAccountId: ''},
    sellerContacts: [{}],
    termsAndConditions: '',
    updateTime: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"billedBuyer":{"accountId":""},"buyer":{},"buyerContacts":[{"email":"","name":""}],"buyerPrivateData":{"referenceId":""},"deals":[{"availableEndTime":"","availableStartTime":"","buyerPrivateData":{},"createProductId":"","createProductRevision":"","createTime":"","creativePreApprovalPolicy":"","creativeRestrictions":{"creativeFormat":"","creativeSpecifications":[{"creativeCompanionSizes":[{"height":"","sizeType":"","width":""}],"creativeSize":{}}],"skippableAdType":""},"creativeSafeFrameCompatibility":"","dealId":"","dealServingMetadata":{"dealPauseStatus":{"buyerPauseReason":"","firstPausedBy":"","hasBuyerPaused":false,"hasSellerPaused":false,"sellerPauseReason":""}},"dealTerms":{"brandingType":"","description":"","estimatedGrossSpend":{"amount":{"currencyCode":"","nanos":0,"units":""},"pricingType":""},"estimatedImpressionsPerDay":"","guaranteedFixedPriceTerms":{"fixedPrices":[{"advertiserIds":[],"buyer":{},"price":{}}],"guaranteedImpressions":"","guaranteedLooks":"","impressionCap":"","minimumDailyLooks":"","percentShareOfVoice":"","reservationType":""},"nonGuaranteedAuctionTerms":{"autoOptimizePrivateAuction":false,"reservePricesPerBuyer":[{}]},"nonGuaranteedFixedPriceTerms":{"fixedPrices":[{}]},"sellerTimeZone":""},"deliveryControl":{"creativeBlockingLevel":"","deliveryRateType":"","frequencyCaps":[{"maxImpressions":0,"numTimeUnits":0,"timeUnitType":""}]},"description":"","displayName":"","externalDealId":"","isSetupComplete":false,"programmaticCreativeSource":"","proposalId":"","sellerContacts":[{}],"syndicationProduct":"","targeting":{"geoTargeting":{"excludedCriteriaIds":[],"targetedCriteriaIds":[]},"inventorySizeTargeting":{"excludedInventorySizes":[{}],"targetedInventorySizes":[{}]},"placementTargeting":{"mobileApplicationTargeting":{"firstPartyTargeting":{"excludedAppIds":[],"targetedAppIds":[]}},"urlTargeting":{"excludedUrls":[],"targetedUrls":[]}},"technologyTargeting":{"deviceCapabilityTargeting":{},"deviceCategoryTargeting":{},"operatingSystemTargeting":{"operatingSystemCriteria":{},"operatingSystemVersionCriteria":{}}},"videoTargeting":{"excludedPositionTypes":[],"targetedPositionTypes":[]}},"targetingCriterion":[{"exclusions":[{"creativeSizeValue":{"allowedFormats":[],"companionSizes":[{"height":0,"width":0}],"creativeSizeType":"","nativeTemplate":"","size":{},"skippableAdType":""},"dayPartTargetingValue":{"dayParts":[{"dayOfWeek":"","endTime":{"hours":0,"minutes":0,"nanos":0,"seconds":0},"startTime":{}}],"timeZoneType":""},"longValue":"","stringValue":""}],"inclusions":[{}],"key":""}],"updateTime":"","webPropertyCode":""}],"displayName":"","isRenegotiating":false,"isSetupComplete":false,"lastUpdaterOrCommentorRole":"","notes":[{"createTime":"","creatorRole":"","note":"","noteId":"","proposalRevision":""}],"originatorRole":"","privateAuctionId":"","proposalId":"","proposalRevision":"","proposalState":"","seller":{"accountId":"","subAccountId":""},"sellerContacts":[{}],"termsAndConditions":"","updateTime":""}'
};

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 = @{ @"billedBuyer": @{ @"accountId": @"" },
                              @"buyer": @{  },
                              @"buyerContacts": @[ @{ @"email": @"", @"name": @"" } ],
                              @"buyerPrivateData": @{ @"referenceId": @"" },
                              @"deals": @[ @{ @"availableEndTime": @"", @"availableStartTime": @"", @"buyerPrivateData": @{  }, @"createProductId": @"", @"createProductRevision": @"", @"createTime": @"", @"creativePreApprovalPolicy": @"", @"creativeRestrictions": @{ @"creativeFormat": @"", @"creativeSpecifications": @[ @{ @"creativeCompanionSizes": @[ @{ @"height": @"", @"sizeType": @"", @"width": @"" } ], @"creativeSize": @{  } } ], @"skippableAdType": @"" }, @"creativeSafeFrameCompatibility": @"", @"dealId": @"", @"dealServingMetadata": @{ @"dealPauseStatus": @{ @"buyerPauseReason": @"", @"firstPausedBy": @"", @"hasBuyerPaused": @NO, @"hasSellerPaused": @NO, @"sellerPauseReason": @"" } }, @"dealTerms": @{ @"brandingType": @"", @"description": @"", @"estimatedGrossSpend": @{ @"amount": @{ @"currencyCode": @"", @"nanos": @0, @"units": @"" }, @"pricingType": @"" }, @"estimatedImpressionsPerDay": @"", @"guaranteedFixedPriceTerms": @{ @"fixedPrices": @[ @{ @"advertiserIds": @[  ], @"buyer": @{  }, @"price": @{  } } ], @"guaranteedImpressions": @"", @"guaranteedLooks": @"", @"impressionCap": @"", @"minimumDailyLooks": @"", @"percentShareOfVoice": @"", @"reservationType": @"" }, @"nonGuaranteedAuctionTerms": @{ @"autoOptimizePrivateAuction": @NO, @"reservePricesPerBuyer": @[ @{  } ] }, @"nonGuaranteedFixedPriceTerms": @{ @"fixedPrices": @[ @{  } ] }, @"sellerTimeZone": @"" }, @"deliveryControl": @{ @"creativeBlockingLevel": @"", @"deliveryRateType": @"", @"frequencyCaps": @[ @{ @"maxImpressions": @0, @"numTimeUnits": @0, @"timeUnitType": @"" } ] }, @"description": @"", @"displayName": @"", @"externalDealId": @"", @"isSetupComplete": @NO, @"programmaticCreativeSource": @"", @"proposalId": @"", @"sellerContacts": @[ @{  } ], @"syndicationProduct": @"", @"targeting": @{ @"geoTargeting": @{ @"excludedCriteriaIds": @[  ], @"targetedCriteriaIds": @[  ] }, @"inventorySizeTargeting": @{ @"excludedInventorySizes": @[ @{  } ], @"targetedInventorySizes": @[ @{  } ] }, @"placementTargeting": @{ @"mobileApplicationTargeting": @{ @"firstPartyTargeting": @{ @"excludedAppIds": @[  ], @"targetedAppIds": @[  ] } }, @"urlTargeting": @{ @"excludedUrls": @[  ], @"targetedUrls": @[  ] } }, @"technologyTargeting": @{ @"deviceCapabilityTargeting": @{  }, @"deviceCategoryTargeting": @{  }, @"operatingSystemTargeting": @{ @"operatingSystemCriteria": @{  }, @"operatingSystemVersionCriteria": @{  } } }, @"videoTargeting": @{ @"excludedPositionTypes": @[  ], @"targetedPositionTypes": @[  ] } }, @"targetingCriterion": @[ @{ @"exclusions": @[ @{ @"creativeSizeValue": @{ @"allowedFormats": @[  ], @"companionSizes": @[ @{ @"height": @0, @"width": @0 } ], @"creativeSizeType": @"", @"nativeTemplate": @"", @"size": @{  }, @"skippableAdType": @"" }, @"dayPartTargetingValue": @{ @"dayParts": @[ @{ @"dayOfWeek": @"", @"endTime": @{ @"hours": @0, @"minutes": @0, @"nanos": @0, @"seconds": @0 }, @"startTime": @{  } } ], @"timeZoneType": @"" }, @"longValue": @"", @"stringValue": @"" } ], @"inclusions": @[ @{  } ], @"key": @"" } ], @"updateTime": @"", @"webPropertyCode": @"" } ],
                              @"displayName": @"",
                              @"isRenegotiating": @NO,
                              @"isSetupComplete": @NO,
                              @"lastUpdaterOrCommentorRole": @"",
                              @"notes": @[ @{ @"createTime": @"", @"creatorRole": @"", @"note": @"", @"noteId": @"", @"proposalRevision": @"" } ],
                              @"originatorRole": @"",
                              @"privateAuctionId": @"",
                              @"proposalId": @"",
                              @"proposalRevision": @"",
                              @"proposalState": @"",
                              @"seller": @{ @"accountId": @"", @"subAccountId": @"" },
                              @"sellerContacts": @[ @{  } ],
                              @"termsAndConditions": @"",
                              @"updateTime": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId"]
                                                       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}}/v2beta1/accounts/:accountId/proposals/:proposalId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId",
  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([
    'billedBuyer' => [
        'accountId' => ''
    ],
    'buyer' => [
        
    ],
    'buyerContacts' => [
        [
                'email' => '',
                'name' => ''
        ]
    ],
    'buyerPrivateData' => [
        'referenceId' => ''
    ],
    'deals' => [
        [
                'availableEndTime' => '',
                'availableStartTime' => '',
                'buyerPrivateData' => [
                                
                ],
                'createProductId' => '',
                'createProductRevision' => '',
                'createTime' => '',
                'creativePreApprovalPolicy' => '',
                'creativeRestrictions' => [
                                'creativeFormat' => '',
                                'creativeSpecifications' => [
                                                                [
                                                                                                                                'creativeCompanionSizes' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'height' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'sizeType' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'width' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ],
                                                                                                                                'creativeSize' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'skippableAdType' => ''
                ],
                'creativeSafeFrameCompatibility' => '',
                'dealId' => '',
                'dealServingMetadata' => [
                                'dealPauseStatus' => [
                                                                'buyerPauseReason' => '',
                                                                'firstPausedBy' => '',
                                                                'hasBuyerPaused' => null,
                                                                'hasSellerPaused' => null,
                                                                'sellerPauseReason' => ''
                                ]
                ],
                'dealTerms' => [
                                'brandingType' => '',
                                'description' => '',
                                'estimatedGrossSpend' => [
                                                                'amount' => [
                                                                                                                                'currencyCode' => '',
                                                                                                                                'nanos' => 0,
                                                                                                                                'units' => ''
                                                                ],
                                                                'pricingType' => ''
                                ],
                                'estimatedImpressionsPerDay' => '',
                                'guaranteedFixedPriceTerms' => [
                                                                'fixedPrices' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'advertiserIds' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'buyer' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'price' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'guaranteedImpressions' => '',
                                                                'guaranteedLooks' => '',
                                                                'impressionCap' => '',
                                                                'minimumDailyLooks' => '',
                                                                'percentShareOfVoice' => '',
                                                                'reservationType' => ''
                                ],
                                'nonGuaranteedAuctionTerms' => [
                                                                'autoOptimizePrivateAuction' => null,
                                                                'reservePricesPerBuyer' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'nonGuaranteedFixedPriceTerms' => [
                                                                'fixedPrices' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'sellerTimeZone' => ''
                ],
                'deliveryControl' => [
                                'creativeBlockingLevel' => '',
                                'deliveryRateType' => '',
                                'frequencyCaps' => [
                                                                [
                                                                                                                                'maxImpressions' => 0,
                                                                                                                                'numTimeUnits' => 0,
                                                                                                                                'timeUnitType' => ''
                                                                ]
                                ]
                ],
                'description' => '',
                'displayName' => '',
                'externalDealId' => '',
                'isSetupComplete' => null,
                'programmaticCreativeSource' => '',
                'proposalId' => '',
                'sellerContacts' => [
                                [
                                                                
                                ]
                ],
                'syndicationProduct' => '',
                'targeting' => [
                                'geoTargeting' => [
                                                                'excludedCriteriaIds' => [
                                                                                                                                
                                                                ],
                                                                'targetedCriteriaIds' => [
                                                                                                                                
                                                                ]
                                ],
                                'inventorySizeTargeting' => [
                                                                'excludedInventorySizes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'targetedInventorySizes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'placementTargeting' => [
                                                                'mobileApplicationTargeting' => [
                                                                                                                                'firstPartyTargeting' => [
                                                                                                                                                                                                                                                                'excludedAppIds' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'targetedAppIds' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'urlTargeting' => [
                                                                                                                                'excludedUrls' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'targetedUrls' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'technologyTargeting' => [
                                                                'deviceCapabilityTargeting' => [
                                                                                                                                
                                                                ],
                                                                'deviceCategoryTargeting' => [
                                                                                                                                
                                                                ],
                                                                'operatingSystemTargeting' => [
                                                                                                                                'operatingSystemCriteria' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'operatingSystemVersionCriteria' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'videoTargeting' => [
                                                                'excludedPositionTypes' => [
                                                                                                                                
                                                                ],
                                                                'targetedPositionTypes' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'targetingCriterion' => [
                                [
                                                                'exclusions' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'creativeSizeValue' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'allowedFormats' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'companionSizes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'creativeSizeType' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'nativeTemplate' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'size' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'skippableAdType' => ''
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'dayPartTargetingValue' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'dayParts' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'dayOfWeek' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'endTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'hours' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'minutes' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'nanos' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'seconds' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'startTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'timeZoneType' => ''
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'longValue' => '',
                                                                                                                                                                                                                                                                'stringValue' => ''
                                                                                                                                ]
                                                                ],
                                                                'inclusions' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'key' => ''
                                ]
                ],
                'updateTime' => '',
                'webPropertyCode' => ''
        ]
    ],
    'displayName' => '',
    'isRenegotiating' => null,
    'isSetupComplete' => null,
    'lastUpdaterOrCommentorRole' => '',
    'notes' => [
        [
                'createTime' => '',
                'creatorRole' => '',
                'note' => '',
                'noteId' => '',
                'proposalRevision' => ''
        ]
    ],
    'originatorRole' => '',
    'privateAuctionId' => '',
    'proposalId' => '',
    'proposalRevision' => '',
    'proposalState' => '',
    'seller' => [
        'accountId' => '',
        'subAccountId' => ''
    ],
    'sellerContacts' => [
        [
                
        ]
    ],
    'termsAndConditions' => '',
    'updateTime' => ''
  ]),
  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}}/v2beta1/accounts/:accountId/proposals/:proposalId', [
  'body' => '{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'billedBuyer' => [
    'accountId' => ''
  ],
  'buyer' => [
    
  ],
  'buyerContacts' => [
    [
        'email' => '',
        'name' => ''
    ]
  ],
  'buyerPrivateData' => [
    'referenceId' => ''
  ],
  'deals' => [
    [
        'availableEndTime' => '',
        'availableStartTime' => '',
        'buyerPrivateData' => [
                
        ],
        'createProductId' => '',
        'createProductRevision' => '',
        'createTime' => '',
        'creativePreApprovalPolicy' => '',
        'creativeRestrictions' => [
                'creativeFormat' => '',
                'creativeSpecifications' => [
                                [
                                                                'creativeCompanionSizes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'height' => '',
                                                                                                                                                                                                                                                                'sizeType' => '',
                                                                                                                                                                                                                                                                'width' => ''
                                                                                                                                ]
                                                                ],
                                                                'creativeSize' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'skippableAdType' => ''
        ],
        'creativeSafeFrameCompatibility' => '',
        'dealId' => '',
        'dealServingMetadata' => [
                'dealPauseStatus' => [
                                'buyerPauseReason' => '',
                                'firstPausedBy' => '',
                                'hasBuyerPaused' => null,
                                'hasSellerPaused' => null,
                                'sellerPauseReason' => ''
                ]
        ],
        'dealTerms' => [
                'brandingType' => '',
                'description' => '',
                'estimatedGrossSpend' => [
                                'amount' => [
                                                                'currencyCode' => '',
                                                                'nanos' => 0,
                                                                'units' => ''
                                ],
                                'pricingType' => ''
                ],
                'estimatedImpressionsPerDay' => '',
                'guaranteedFixedPriceTerms' => [
                                'fixedPrices' => [
                                                                [
                                                                                                                                'advertiserIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'buyer' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'price' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'guaranteedImpressions' => '',
                                'guaranteedLooks' => '',
                                'impressionCap' => '',
                                'minimumDailyLooks' => '',
                                'percentShareOfVoice' => '',
                                'reservationType' => ''
                ],
                'nonGuaranteedAuctionTerms' => [
                                'autoOptimizePrivateAuction' => null,
                                'reservePricesPerBuyer' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'nonGuaranteedFixedPriceTerms' => [
                                'fixedPrices' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'sellerTimeZone' => ''
        ],
        'deliveryControl' => [
                'creativeBlockingLevel' => '',
                'deliveryRateType' => '',
                'frequencyCaps' => [
                                [
                                                                'maxImpressions' => 0,
                                                                'numTimeUnits' => 0,
                                                                'timeUnitType' => ''
                                ]
                ]
        ],
        'description' => '',
        'displayName' => '',
        'externalDealId' => '',
        'isSetupComplete' => null,
        'programmaticCreativeSource' => '',
        'proposalId' => '',
        'sellerContacts' => [
                [
                                
                ]
        ],
        'syndicationProduct' => '',
        'targeting' => [
                'geoTargeting' => [
                                'excludedCriteriaIds' => [
                                                                
                                ],
                                'targetedCriteriaIds' => [
                                                                
                                ]
                ],
                'inventorySizeTargeting' => [
                                'excludedInventorySizes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'targetedInventorySizes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'placementTargeting' => [
                                'mobileApplicationTargeting' => [
                                                                'firstPartyTargeting' => [
                                                                                                                                'excludedAppIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'targetedAppIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'urlTargeting' => [
                                                                'excludedUrls' => [
                                                                                                                                
                                                                ],
                                                                'targetedUrls' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'technologyTargeting' => [
                                'deviceCapabilityTargeting' => [
                                                                
                                ],
                                'deviceCategoryTargeting' => [
                                                                
                                ],
                                'operatingSystemTargeting' => [
                                                                'operatingSystemCriteria' => [
                                                                                                                                
                                                                ],
                                                                'operatingSystemVersionCriteria' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'videoTargeting' => [
                                'excludedPositionTypes' => [
                                                                
                                ],
                                'targetedPositionTypes' => [
                                                                
                                ]
                ]
        ],
        'targetingCriterion' => [
                [
                                'exclusions' => [
                                                                [
                                                                                                                                'creativeSizeValue' => [
                                                                                                                                                                                                                                                                'allowedFormats' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'companionSizes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'creativeSizeType' => '',
                                                                                                                                                                                                                                                                'nativeTemplate' => '',
                                                                                                                                                                                                                                                                'size' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'skippableAdType' => ''
                                                                                                                                ],
                                                                                                                                'dayPartTargetingValue' => [
                                                                                                                                                                                                                                                                'dayParts' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'dayOfWeek' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'endTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'hours' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'minutes' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'nanos' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'seconds' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'startTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'timeZoneType' => ''
                                                                                                                                ],
                                                                                                                                'longValue' => '',
                                                                                                                                'stringValue' => ''
                                                                ]
                                ],
                                'inclusions' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'key' => ''
                ]
        ],
        'updateTime' => '',
        'webPropertyCode' => ''
    ]
  ],
  'displayName' => '',
  'isRenegotiating' => null,
  'isSetupComplete' => null,
  'lastUpdaterOrCommentorRole' => '',
  'notes' => [
    [
        'createTime' => '',
        'creatorRole' => '',
        'note' => '',
        'noteId' => '',
        'proposalRevision' => ''
    ]
  ],
  'originatorRole' => '',
  'privateAuctionId' => '',
  'proposalId' => '',
  'proposalRevision' => '',
  'proposalState' => '',
  'seller' => [
    'accountId' => '',
    'subAccountId' => ''
  ],
  'sellerContacts' => [
    [
        
    ]
  ],
  'termsAndConditions' => '',
  'updateTime' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'billedBuyer' => [
    'accountId' => ''
  ],
  'buyer' => [
    
  ],
  'buyerContacts' => [
    [
        'email' => '',
        'name' => ''
    ]
  ],
  'buyerPrivateData' => [
    'referenceId' => ''
  ],
  'deals' => [
    [
        'availableEndTime' => '',
        'availableStartTime' => '',
        'buyerPrivateData' => [
                
        ],
        'createProductId' => '',
        'createProductRevision' => '',
        'createTime' => '',
        'creativePreApprovalPolicy' => '',
        'creativeRestrictions' => [
                'creativeFormat' => '',
                'creativeSpecifications' => [
                                [
                                                                'creativeCompanionSizes' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'height' => '',
                                                                                                                                                                                                                                                                'sizeType' => '',
                                                                                                                                                                                                                                                                'width' => ''
                                                                                                                                ]
                                                                ],
                                                                'creativeSize' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'skippableAdType' => ''
        ],
        'creativeSafeFrameCompatibility' => '',
        'dealId' => '',
        'dealServingMetadata' => [
                'dealPauseStatus' => [
                                'buyerPauseReason' => '',
                                'firstPausedBy' => '',
                                'hasBuyerPaused' => null,
                                'hasSellerPaused' => null,
                                'sellerPauseReason' => ''
                ]
        ],
        'dealTerms' => [
                'brandingType' => '',
                'description' => '',
                'estimatedGrossSpend' => [
                                'amount' => [
                                                                'currencyCode' => '',
                                                                'nanos' => 0,
                                                                'units' => ''
                                ],
                                'pricingType' => ''
                ],
                'estimatedImpressionsPerDay' => '',
                'guaranteedFixedPriceTerms' => [
                                'fixedPrices' => [
                                                                [
                                                                                                                                'advertiserIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'buyer' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'price' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'guaranteedImpressions' => '',
                                'guaranteedLooks' => '',
                                'impressionCap' => '',
                                'minimumDailyLooks' => '',
                                'percentShareOfVoice' => '',
                                'reservationType' => ''
                ],
                'nonGuaranteedAuctionTerms' => [
                                'autoOptimizePrivateAuction' => null,
                                'reservePricesPerBuyer' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'nonGuaranteedFixedPriceTerms' => [
                                'fixedPrices' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'sellerTimeZone' => ''
        ],
        'deliveryControl' => [
                'creativeBlockingLevel' => '',
                'deliveryRateType' => '',
                'frequencyCaps' => [
                                [
                                                                'maxImpressions' => 0,
                                                                'numTimeUnits' => 0,
                                                                'timeUnitType' => ''
                                ]
                ]
        ],
        'description' => '',
        'displayName' => '',
        'externalDealId' => '',
        'isSetupComplete' => null,
        'programmaticCreativeSource' => '',
        'proposalId' => '',
        'sellerContacts' => [
                [
                                
                ]
        ],
        'syndicationProduct' => '',
        'targeting' => [
                'geoTargeting' => [
                                'excludedCriteriaIds' => [
                                                                
                                ],
                                'targetedCriteriaIds' => [
                                                                
                                ]
                ],
                'inventorySizeTargeting' => [
                                'excludedInventorySizes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'targetedInventorySizes' => [
                                                                [
                                                                                                                                
                                                                ]
                                ]
                ],
                'placementTargeting' => [
                                'mobileApplicationTargeting' => [
                                                                'firstPartyTargeting' => [
                                                                                                                                'excludedAppIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'targetedAppIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'urlTargeting' => [
                                                                'excludedUrls' => [
                                                                                                                                
                                                                ],
                                                                'targetedUrls' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'technologyTargeting' => [
                                'deviceCapabilityTargeting' => [
                                                                
                                ],
                                'deviceCategoryTargeting' => [
                                                                
                                ],
                                'operatingSystemTargeting' => [
                                                                'operatingSystemCriteria' => [
                                                                                                                                
                                                                ],
                                                                'operatingSystemVersionCriteria' => [
                                                                                                                                
                                                                ]
                                ]
                ],
                'videoTargeting' => [
                                'excludedPositionTypes' => [
                                                                
                                ],
                                'targetedPositionTypes' => [
                                                                
                                ]
                ]
        ],
        'targetingCriterion' => [
                [
                                'exclusions' => [
                                                                [
                                                                                                                                'creativeSizeValue' => [
                                                                                                                                                                                                                                                                'allowedFormats' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'companionSizes' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'height' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'width' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'creativeSizeType' => '',
                                                                                                                                                                                                                                                                'nativeTemplate' => '',
                                                                                                                                                                                                                                                                'size' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'skippableAdType' => ''
                                                                                                                                ],
                                                                                                                                'dayPartTargetingValue' => [
                                                                                                                                                                                                                                                                'dayParts' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'dayOfWeek' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'endTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'hours' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'minutes' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'nanos' => 0,
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'seconds' => 0
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'startTime' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'timeZoneType' => ''
                                                                                                                                ],
                                                                                                                                'longValue' => '',
                                                                                                                                'stringValue' => ''
                                                                ]
                                ],
                                'inclusions' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'key' => ''
                ]
        ],
        'updateTime' => '',
        'webPropertyCode' => ''
    ]
  ],
  'displayName' => '',
  'isRenegotiating' => null,
  'isSetupComplete' => null,
  'lastUpdaterOrCommentorRole' => '',
  'notes' => [
    [
        'createTime' => '',
        'creatorRole' => '',
        'note' => '',
        'noteId' => '',
        'proposalRevision' => ''
    ]
  ],
  'originatorRole' => '',
  'privateAuctionId' => '',
  'proposalId' => '',
  'proposalRevision' => '',
  'proposalState' => '',
  'seller' => [
    'accountId' => '',
    'subAccountId' => ''
  ],
  'sellerContacts' => [
    [
        
    ]
  ],
  'termsAndConditions' => '',
  'updateTime' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId');
$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}}/v2beta1/accounts/:accountId/proposals/:proposalId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/v2beta1/accounts/:accountId/proposals/:proposalId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId"

payload = {
    "billedBuyer": { "accountId": "" },
    "buyer": {},
    "buyerContacts": [
        {
            "email": "",
            "name": ""
        }
    ],
    "buyerPrivateData": { "referenceId": "" },
    "deals": [
        {
            "availableEndTime": "",
            "availableStartTime": "",
            "buyerPrivateData": {},
            "createProductId": "",
            "createProductRevision": "",
            "createTime": "",
            "creativePreApprovalPolicy": "",
            "creativeRestrictions": {
                "creativeFormat": "",
                "creativeSpecifications": [
                    {
                        "creativeCompanionSizes": [
                            {
                                "height": "",
                                "sizeType": "",
                                "width": ""
                            }
                        ],
                        "creativeSize": {}
                    }
                ],
                "skippableAdType": ""
            },
            "creativeSafeFrameCompatibility": "",
            "dealId": "",
            "dealServingMetadata": { "dealPauseStatus": {
                    "buyerPauseReason": "",
                    "firstPausedBy": "",
                    "hasBuyerPaused": False,
                    "hasSellerPaused": False,
                    "sellerPauseReason": ""
                } },
            "dealTerms": {
                "brandingType": "",
                "description": "",
                "estimatedGrossSpend": {
                    "amount": {
                        "currencyCode": "",
                        "nanos": 0,
                        "units": ""
                    },
                    "pricingType": ""
                },
                "estimatedImpressionsPerDay": "",
                "guaranteedFixedPriceTerms": {
                    "fixedPrices": [
                        {
                            "advertiserIds": [],
                            "buyer": {},
                            "price": {}
                        }
                    ],
                    "guaranteedImpressions": "",
                    "guaranteedLooks": "",
                    "impressionCap": "",
                    "minimumDailyLooks": "",
                    "percentShareOfVoice": "",
                    "reservationType": ""
                },
                "nonGuaranteedAuctionTerms": {
                    "autoOptimizePrivateAuction": False,
                    "reservePricesPerBuyer": [{}]
                },
                "nonGuaranteedFixedPriceTerms": { "fixedPrices": [{}] },
                "sellerTimeZone": ""
            },
            "deliveryControl": {
                "creativeBlockingLevel": "",
                "deliveryRateType": "",
                "frequencyCaps": [
                    {
                        "maxImpressions": 0,
                        "numTimeUnits": 0,
                        "timeUnitType": ""
                    }
                ]
            },
            "description": "",
            "displayName": "",
            "externalDealId": "",
            "isSetupComplete": False,
            "programmaticCreativeSource": "",
            "proposalId": "",
            "sellerContacts": [{}],
            "syndicationProduct": "",
            "targeting": {
                "geoTargeting": {
                    "excludedCriteriaIds": [],
                    "targetedCriteriaIds": []
                },
                "inventorySizeTargeting": {
                    "excludedInventorySizes": [{}],
                    "targetedInventorySizes": [{}]
                },
                "placementTargeting": {
                    "mobileApplicationTargeting": { "firstPartyTargeting": {
                            "excludedAppIds": [],
                            "targetedAppIds": []
                        } },
                    "urlTargeting": {
                        "excludedUrls": [],
                        "targetedUrls": []
                    }
                },
                "technologyTargeting": {
                    "deviceCapabilityTargeting": {},
                    "deviceCategoryTargeting": {},
                    "operatingSystemTargeting": {
                        "operatingSystemCriteria": {},
                        "operatingSystemVersionCriteria": {}
                    }
                },
                "videoTargeting": {
                    "excludedPositionTypes": [],
                    "targetedPositionTypes": []
                }
            },
            "targetingCriterion": [
                {
                    "exclusions": [
                        {
                            "creativeSizeValue": {
                                "allowedFormats": [],
                                "companionSizes": [
                                    {
                                        "height": 0,
                                        "width": 0
                                    }
                                ],
                                "creativeSizeType": "",
                                "nativeTemplate": "",
                                "size": {},
                                "skippableAdType": ""
                            },
                            "dayPartTargetingValue": {
                                "dayParts": [
                                    {
                                        "dayOfWeek": "",
                                        "endTime": {
                                            "hours": 0,
                                            "minutes": 0,
                                            "nanos": 0,
                                            "seconds": 0
                                        },
                                        "startTime": {}
                                    }
                                ],
                                "timeZoneType": ""
                            },
                            "longValue": "",
                            "stringValue": ""
                        }
                    ],
                    "inclusions": [{}],
                    "key": ""
                }
            ],
            "updateTime": "",
            "webPropertyCode": ""
        }
    ],
    "displayName": "",
    "isRenegotiating": False,
    "isSetupComplete": False,
    "lastUpdaterOrCommentorRole": "",
    "notes": [
        {
            "createTime": "",
            "creatorRole": "",
            "note": "",
            "noteId": "",
            "proposalRevision": ""
        }
    ],
    "originatorRole": "",
    "privateAuctionId": "",
    "proposalId": "",
    "proposalRevision": "",
    "proposalState": "",
    "seller": {
        "accountId": "",
        "subAccountId": ""
    },
    "sellerContacts": [{}],
    "termsAndConditions": "",
    "updateTime": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId"

payload <- "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\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}}/v2beta1/accounts/:accountId/proposals/:proposalId")

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  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\n}"

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/v2beta1/accounts/:accountId/proposals/:proposalId') do |req|
  req.body = "{\n  \"billedBuyer\": {\n    \"accountId\": \"\"\n  },\n  \"buyer\": {},\n  \"buyerContacts\": [\n    {\n      \"email\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"buyerPrivateData\": {\n    \"referenceId\": \"\"\n  },\n  \"deals\": [\n    {\n      \"availableEndTime\": \"\",\n      \"availableStartTime\": \"\",\n      \"buyerPrivateData\": {},\n      \"createProductId\": \"\",\n      \"createProductRevision\": \"\",\n      \"createTime\": \"\",\n      \"creativePreApprovalPolicy\": \"\",\n      \"creativeRestrictions\": {\n        \"creativeFormat\": \"\",\n        \"creativeSpecifications\": [\n          {\n            \"creativeCompanionSizes\": [\n              {\n                \"height\": \"\",\n                \"sizeType\": \"\",\n                \"width\": \"\"\n              }\n            ],\n            \"creativeSize\": {}\n          }\n        ],\n        \"skippableAdType\": \"\"\n      },\n      \"creativeSafeFrameCompatibility\": \"\",\n      \"dealId\": \"\",\n      \"dealServingMetadata\": {\n        \"dealPauseStatus\": {\n          \"buyerPauseReason\": \"\",\n          \"firstPausedBy\": \"\",\n          \"hasBuyerPaused\": false,\n          \"hasSellerPaused\": false,\n          \"sellerPauseReason\": \"\"\n        }\n      },\n      \"dealTerms\": {\n        \"brandingType\": \"\",\n        \"description\": \"\",\n        \"estimatedGrossSpend\": {\n          \"amount\": {\n            \"currencyCode\": \"\",\n            \"nanos\": 0,\n            \"units\": \"\"\n          },\n          \"pricingType\": \"\"\n        },\n        \"estimatedImpressionsPerDay\": \"\",\n        \"guaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {\n              \"advertiserIds\": [],\n              \"buyer\": {},\n              \"price\": {}\n            }\n          ],\n          \"guaranteedImpressions\": \"\",\n          \"guaranteedLooks\": \"\",\n          \"impressionCap\": \"\",\n          \"minimumDailyLooks\": \"\",\n          \"percentShareOfVoice\": \"\",\n          \"reservationType\": \"\"\n        },\n        \"nonGuaranteedAuctionTerms\": {\n          \"autoOptimizePrivateAuction\": false,\n          \"reservePricesPerBuyer\": [\n            {}\n          ]\n        },\n        \"nonGuaranteedFixedPriceTerms\": {\n          \"fixedPrices\": [\n            {}\n          ]\n        },\n        \"sellerTimeZone\": \"\"\n      },\n      \"deliveryControl\": {\n        \"creativeBlockingLevel\": \"\",\n        \"deliveryRateType\": \"\",\n        \"frequencyCaps\": [\n          {\n            \"maxImpressions\": 0,\n            \"numTimeUnits\": 0,\n            \"timeUnitType\": \"\"\n          }\n        ]\n      },\n      \"description\": \"\",\n      \"displayName\": \"\",\n      \"externalDealId\": \"\",\n      \"isSetupComplete\": false,\n      \"programmaticCreativeSource\": \"\",\n      \"proposalId\": \"\",\n      \"sellerContacts\": [\n        {}\n      ],\n      \"syndicationProduct\": \"\",\n      \"targeting\": {\n        \"geoTargeting\": {\n          \"excludedCriteriaIds\": [],\n          \"targetedCriteriaIds\": []\n        },\n        \"inventorySizeTargeting\": {\n          \"excludedInventorySizes\": [\n            {}\n          ],\n          \"targetedInventorySizes\": [\n            {}\n          ]\n        },\n        \"placementTargeting\": {\n          \"mobileApplicationTargeting\": {\n            \"firstPartyTargeting\": {\n              \"excludedAppIds\": [],\n              \"targetedAppIds\": []\n            }\n          },\n          \"urlTargeting\": {\n            \"excludedUrls\": [],\n            \"targetedUrls\": []\n          }\n        },\n        \"technologyTargeting\": {\n          \"deviceCapabilityTargeting\": {},\n          \"deviceCategoryTargeting\": {},\n          \"operatingSystemTargeting\": {\n            \"operatingSystemCriteria\": {},\n            \"operatingSystemVersionCriteria\": {}\n          }\n        },\n        \"videoTargeting\": {\n          \"excludedPositionTypes\": [],\n          \"targetedPositionTypes\": []\n        }\n      },\n      \"targetingCriterion\": [\n        {\n          \"exclusions\": [\n            {\n              \"creativeSizeValue\": {\n                \"allowedFormats\": [],\n                \"companionSizes\": [\n                  {\n                    \"height\": 0,\n                    \"width\": 0\n                  }\n                ],\n                \"creativeSizeType\": \"\",\n                \"nativeTemplate\": \"\",\n                \"size\": {},\n                \"skippableAdType\": \"\"\n              },\n              \"dayPartTargetingValue\": {\n                \"dayParts\": [\n                  {\n                    \"dayOfWeek\": \"\",\n                    \"endTime\": {\n                      \"hours\": 0,\n                      \"minutes\": 0,\n                      \"nanos\": 0,\n                      \"seconds\": 0\n                    },\n                    \"startTime\": {}\n                  }\n                ],\n                \"timeZoneType\": \"\"\n              },\n              \"longValue\": \"\",\n              \"stringValue\": \"\"\n            }\n          ],\n          \"inclusions\": [\n            {}\n          ],\n          \"key\": \"\"\n        }\n      ],\n      \"updateTime\": \"\",\n      \"webPropertyCode\": \"\"\n    }\n  ],\n  \"displayName\": \"\",\n  \"isRenegotiating\": false,\n  \"isSetupComplete\": false,\n  \"lastUpdaterOrCommentorRole\": \"\",\n  \"notes\": [\n    {\n      \"createTime\": \"\",\n      \"creatorRole\": \"\",\n      \"note\": \"\",\n      \"noteId\": \"\",\n      \"proposalRevision\": \"\"\n    }\n  ],\n  \"originatorRole\": \"\",\n  \"privateAuctionId\": \"\",\n  \"proposalId\": \"\",\n  \"proposalRevision\": \"\",\n  \"proposalState\": \"\",\n  \"seller\": {\n    \"accountId\": \"\",\n    \"subAccountId\": \"\"\n  },\n  \"sellerContacts\": [\n    {}\n  ],\n  \"termsAndConditions\": \"\",\n  \"updateTime\": \"\"\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}}/v2beta1/accounts/:accountId/proposals/:proposalId";

    let payload = json!({
        "billedBuyer": json!({"accountId": ""}),
        "buyer": json!({}),
        "buyerContacts": (
            json!({
                "email": "",
                "name": ""
            })
        ),
        "buyerPrivateData": json!({"referenceId": ""}),
        "deals": (
            json!({
                "availableEndTime": "",
                "availableStartTime": "",
                "buyerPrivateData": json!({}),
                "createProductId": "",
                "createProductRevision": "",
                "createTime": "",
                "creativePreApprovalPolicy": "",
                "creativeRestrictions": json!({
                    "creativeFormat": "",
                    "creativeSpecifications": (
                        json!({
                            "creativeCompanionSizes": (
                                json!({
                                    "height": "",
                                    "sizeType": "",
                                    "width": ""
                                })
                            ),
                            "creativeSize": json!({})
                        })
                    ),
                    "skippableAdType": ""
                }),
                "creativeSafeFrameCompatibility": "",
                "dealId": "",
                "dealServingMetadata": json!({"dealPauseStatus": json!({
                        "buyerPauseReason": "",
                        "firstPausedBy": "",
                        "hasBuyerPaused": false,
                        "hasSellerPaused": false,
                        "sellerPauseReason": ""
                    })}),
                "dealTerms": json!({
                    "brandingType": "",
                    "description": "",
                    "estimatedGrossSpend": json!({
                        "amount": json!({
                            "currencyCode": "",
                            "nanos": 0,
                            "units": ""
                        }),
                        "pricingType": ""
                    }),
                    "estimatedImpressionsPerDay": "",
                    "guaranteedFixedPriceTerms": json!({
                        "fixedPrices": (
                            json!({
                                "advertiserIds": (),
                                "buyer": json!({}),
                                "price": json!({})
                            })
                        ),
                        "guaranteedImpressions": "",
                        "guaranteedLooks": "",
                        "impressionCap": "",
                        "minimumDailyLooks": "",
                        "percentShareOfVoice": "",
                        "reservationType": ""
                    }),
                    "nonGuaranteedAuctionTerms": json!({
                        "autoOptimizePrivateAuction": false,
                        "reservePricesPerBuyer": (json!({}))
                    }),
                    "nonGuaranteedFixedPriceTerms": json!({"fixedPrices": (json!({}))}),
                    "sellerTimeZone": ""
                }),
                "deliveryControl": json!({
                    "creativeBlockingLevel": "",
                    "deliveryRateType": "",
                    "frequencyCaps": (
                        json!({
                            "maxImpressions": 0,
                            "numTimeUnits": 0,
                            "timeUnitType": ""
                        })
                    )
                }),
                "description": "",
                "displayName": "",
                "externalDealId": "",
                "isSetupComplete": false,
                "programmaticCreativeSource": "",
                "proposalId": "",
                "sellerContacts": (json!({})),
                "syndicationProduct": "",
                "targeting": json!({
                    "geoTargeting": json!({
                        "excludedCriteriaIds": (),
                        "targetedCriteriaIds": ()
                    }),
                    "inventorySizeTargeting": json!({
                        "excludedInventorySizes": (json!({})),
                        "targetedInventorySizes": (json!({}))
                    }),
                    "placementTargeting": json!({
                        "mobileApplicationTargeting": json!({"firstPartyTargeting": json!({
                                "excludedAppIds": (),
                                "targetedAppIds": ()
                            })}),
                        "urlTargeting": json!({
                            "excludedUrls": (),
                            "targetedUrls": ()
                        })
                    }),
                    "technologyTargeting": json!({
                        "deviceCapabilityTargeting": json!({}),
                        "deviceCategoryTargeting": json!({}),
                        "operatingSystemTargeting": json!({
                            "operatingSystemCriteria": json!({}),
                            "operatingSystemVersionCriteria": json!({})
                        })
                    }),
                    "videoTargeting": json!({
                        "excludedPositionTypes": (),
                        "targetedPositionTypes": ()
                    })
                }),
                "targetingCriterion": (
                    json!({
                        "exclusions": (
                            json!({
                                "creativeSizeValue": json!({
                                    "allowedFormats": (),
                                    "companionSizes": (
                                        json!({
                                            "height": 0,
                                            "width": 0
                                        })
                                    ),
                                    "creativeSizeType": "",
                                    "nativeTemplate": "",
                                    "size": json!({}),
                                    "skippableAdType": ""
                                }),
                                "dayPartTargetingValue": json!({
                                    "dayParts": (
                                        json!({
                                            "dayOfWeek": "",
                                            "endTime": json!({
                                                "hours": 0,
                                                "minutes": 0,
                                                "nanos": 0,
                                                "seconds": 0
                                            }),
                                            "startTime": json!({})
                                        })
                                    ),
                                    "timeZoneType": ""
                                }),
                                "longValue": "",
                                "stringValue": ""
                            })
                        ),
                        "inclusions": (json!({})),
                        "key": ""
                    })
                ),
                "updateTime": "",
                "webPropertyCode": ""
            })
        ),
        "displayName": "",
        "isRenegotiating": false,
        "isSetupComplete": false,
        "lastUpdaterOrCommentorRole": "",
        "notes": (
            json!({
                "createTime": "",
                "creatorRole": "",
                "note": "",
                "noteId": "",
                "proposalRevision": ""
            })
        ),
        "originatorRole": "",
        "privateAuctionId": "",
        "proposalId": "",
        "proposalRevision": "",
        "proposalState": "",
        "seller": json!({
            "accountId": "",
            "subAccountId": ""
        }),
        "sellerContacts": (json!({})),
        "termsAndConditions": "",
        "updateTime": ""
    });

    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}}/v2beta1/accounts/:accountId/proposals/:proposalId \
  --header 'content-type: application/json' \
  --data '{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}'
echo '{
  "billedBuyer": {
    "accountId": ""
  },
  "buyer": {},
  "buyerContacts": [
    {
      "email": "",
      "name": ""
    }
  ],
  "buyerPrivateData": {
    "referenceId": ""
  },
  "deals": [
    {
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": {},
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": {
        "creativeFormat": "",
        "creativeSpecifications": [
          {
            "creativeCompanionSizes": [
              {
                "height": "",
                "sizeType": "",
                "width": ""
              }
            ],
            "creativeSize": {}
          }
        ],
        "skippableAdType": ""
      },
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": {
        "dealPauseStatus": {
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        }
      },
      "dealTerms": {
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": {
          "amount": {
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          },
          "pricingType": ""
        },
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": {
          "fixedPrices": [
            {
              "advertiserIds": [],
              "buyer": {},
              "price": {}
            }
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        },
        "nonGuaranteedAuctionTerms": {
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [
            {}
          ]
        },
        "nonGuaranteedFixedPriceTerms": {
          "fixedPrices": [
            {}
          ]
        },
        "sellerTimeZone": ""
      },
      "deliveryControl": {
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          {
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          }
        ]
      },
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [
        {}
      ],
      "syndicationProduct": "",
      "targeting": {
        "geoTargeting": {
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        },
        "inventorySizeTargeting": {
          "excludedInventorySizes": [
            {}
          ],
          "targetedInventorySizes": [
            {}
          ]
        },
        "placementTargeting": {
          "mobileApplicationTargeting": {
            "firstPartyTargeting": {
              "excludedAppIds": [],
              "targetedAppIds": []
            }
          },
          "urlTargeting": {
            "excludedUrls": [],
            "targetedUrls": []
          }
        },
        "technologyTargeting": {
          "deviceCapabilityTargeting": {},
          "deviceCategoryTargeting": {},
          "operatingSystemTargeting": {
            "operatingSystemCriteria": {},
            "operatingSystemVersionCriteria": {}
          }
        },
        "videoTargeting": {
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        }
      },
      "targetingCriterion": [
        {
          "exclusions": [
            {
              "creativeSizeValue": {
                "allowedFormats": [],
                "companionSizes": [
                  {
                    "height": 0,
                    "width": 0
                  }
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": {},
                "skippableAdType": ""
              },
              "dayPartTargetingValue": {
                "dayParts": [
                  {
                    "dayOfWeek": "",
                    "endTime": {
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    },
                    "startTime": {}
                  }
                ],
                "timeZoneType": ""
              },
              "longValue": "",
              "stringValue": ""
            }
          ],
          "inclusions": [
            {}
          ],
          "key": ""
        }
      ],
      "updateTime": "",
      "webPropertyCode": ""
    }
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    {
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    }
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": {
    "accountId": "",
    "subAccountId": ""
  },
  "sellerContacts": [
    {}
  ],
  "termsAndConditions": "",
  "updateTime": ""
}' |  \
  http PUT {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "billedBuyer": {\n    "accountId": ""\n  },\n  "buyer": {},\n  "buyerContacts": [\n    {\n      "email": "",\n      "name": ""\n    }\n  ],\n  "buyerPrivateData": {\n    "referenceId": ""\n  },\n  "deals": [\n    {\n      "availableEndTime": "",\n      "availableStartTime": "",\n      "buyerPrivateData": {},\n      "createProductId": "",\n      "createProductRevision": "",\n      "createTime": "",\n      "creativePreApprovalPolicy": "",\n      "creativeRestrictions": {\n        "creativeFormat": "",\n        "creativeSpecifications": [\n          {\n            "creativeCompanionSizes": [\n              {\n                "height": "",\n                "sizeType": "",\n                "width": ""\n              }\n            ],\n            "creativeSize": {}\n          }\n        ],\n        "skippableAdType": ""\n      },\n      "creativeSafeFrameCompatibility": "",\n      "dealId": "",\n      "dealServingMetadata": {\n        "dealPauseStatus": {\n          "buyerPauseReason": "",\n          "firstPausedBy": "",\n          "hasBuyerPaused": false,\n          "hasSellerPaused": false,\n          "sellerPauseReason": ""\n        }\n      },\n      "dealTerms": {\n        "brandingType": "",\n        "description": "",\n        "estimatedGrossSpend": {\n          "amount": {\n            "currencyCode": "",\n            "nanos": 0,\n            "units": ""\n          },\n          "pricingType": ""\n        },\n        "estimatedImpressionsPerDay": "",\n        "guaranteedFixedPriceTerms": {\n          "fixedPrices": [\n            {\n              "advertiserIds": [],\n              "buyer": {},\n              "price": {}\n            }\n          ],\n          "guaranteedImpressions": "",\n          "guaranteedLooks": "",\n          "impressionCap": "",\n          "minimumDailyLooks": "",\n          "percentShareOfVoice": "",\n          "reservationType": ""\n        },\n        "nonGuaranteedAuctionTerms": {\n          "autoOptimizePrivateAuction": false,\n          "reservePricesPerBuyer": [\n            {}\n          ]\n        },\n        "nonGuaranteedFixedPriceTerms": {\n          "fixedPrices": [\n            {}\n          ]\n        },\n        "sellerTimeZone": ""\n      },\n      "deliveryControl": {\n        "creativeBlockingLevel": "",\n        "deliveryRateType": "",\n        "frequencyCaps": [\n          {\n            "maxImpressions": 0,\n            "numTimeUnits": 0,\n            "timeUnitType": ""\n          }\n        ]\n      },\n      "description": "",\n      "displayName": "",\n      "externalDealId": "",\n      "isSetupComplete": false,\n      "programmaticCreativeSource": "",\n      "proposalId": "",\n      "sellerContacts": [\n        {}\n      ],\n      "syndicationProduct": "",\n      "targeting": {\n        "geoTargeting": {\n          "excludedCriteriaIds": [],\n          "targetedCriteriaIds": []\n        },\n        "inventorySizeTargeting": {\n          "excludedInventorySizes": [\n            {}\n          ],\n          "targetedInventorySizes": [\n            {}\n          ]\n        },\n        "placementTargeting": {\n          "mobileApplicationTargeting": {\n            "firstPartyTargeting": {\n              "excludedAppIds": [],\n              "targetedAppIds": []\n            }\n          },\n          "urlTargeting": {\n            "excludedUrls": [],\n            "targetedUrls": []\n          }\n        },\n        "technologyTargeting": {\n          "deviceCapabilityTargeting": {},\n          "deviceCategoryTargeting": {},\n          "operatingSystemTargeting": {\n            "operatingSystemCriteria": {},\n            "operatingSystemVersionCriteria": {}\n          }\n        },\n        "videoTargeting": {\n          "excludedPositionTypes": [],\n          "targetedPositionTypes": []\n        }\n      },\n      "targetingCriterion": [\n        {\n          "exclusions": [\n            {\n              "creativeSizeValue": {\n                "allowedFormats": [],\n                "companionSizes": [\n                  {\n                    "height": 0,\n                    "width": 0\n                  }\n                ],\n                "creativeSizeType": "",\n                "nativeTemplate": "",\n                "size": {},\n                "skippableAdType": ""\n              },\n              "dayPartTargetingValue": {\n                "dayParts": [\n                  {\n                    "dayOfWeek": "",\n                    "endTime": {\n                      "hours": 0,\n                      "minutes": 0,\n                      "nanos": 0,\n                      "seconds": 0\n                    },\n                    "startTime": {}\n                  }\n                ],\n                "timeZoneType": ""\n              },\n              "longValue": "",\n              "stringValue": ""\n            }\n          ],\n          "inclusions": [\n            {}\n          ],\n          "key": ""\n        }\n      ],\n      "updateTime": "",\n      "webPropertyCode": ""\n    }\n  ],\n  "displayName": "",\n  "isRenegotiating": false,\n  "isSetupComplete": false,\n  "lastUpdaterOrCommentorRole": "",\n  "notes": [\n    {\n      "createTime": "",\n      "creatorRole": "",\n      "note": "",\n      "noteId": "",\n      "proposalRevision": ""\n    }\n  ],\n  "originatorRole": "",\n  "privateAuctionId": "",\n  "proposalId": "",\n  "proposalRevision": "",\n  "proposalState": "",\n  "seller": {\n    "accountId": "",\n    "subAccountId": ""\n  },\n  "sellerContacts": [\n    {}\n  ],\n  "termsAndConditions": "",\n  "updateTime": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "billedBuyer": ["accountId": ""],
  "buyer": [],
  "buyerContacts": [
    [
      "email": "",
      "name": ""
    ]
  ],
  "buyerPrivateData": ["referenceId": ""],
  "deals": [
    [
      "availableEndTime": "",
      "availableStartTime": "",
      "buyerPrivateData": [],
      "createProductId": "",
      "createProductRevision": "",
      "createTime": "",
      "creativePreApprovalPolicy": "",
      "creativeRestrictions": [
        "creativeFormat": "",
        "creativeSpecifications": [
          [
            "creativeCompanionSizes": [
              [
                "height": "",
                "sizeType": "",
                "width": ""
              ]
            ],
            "creativeSize": []
          ]
        ],
        "skippableAdType": ""
      ],
      "creativeSafeFrameCompatibility": "",
      "dealId": "",
      "dealServingMetadata": ["dealPauseStatus": [
          "buyerPauseReason": "",
          "firstPausedBy": "",
          "hasBuyerPaused": false,
          "hasSellerPaused": false,
          "sellerPauseReason": ""
        ]],
      "dealTerms": [
        "brandingType": "",
        "description": "",
        "estimatedGrossSpend": [
          "amount": [
            "currencyCode": "",
            "nanos": 0,
            "units": ""
          ],
          "pricingType": ""
        ],
        "estimatedImpressionsPerDay": "",
        "guaranteedFixedPriceTerms": [
          "fixedPrices": [
            [
              "advertiserIds": [],
              "buyer": [],
              "price": []
            ]
          ],
          "guaranteedImpressions": "",
          "guaranteedLooks": "",
          "impressionCap": "",
          "minimumDailyLooks": "",
          "percentShareOfVoice": "",
          "reservationType": ""
        ],
        "nonGuaranteedAuctionTerms": [
          "autoOptimizePrivateAuction": false,
          "reservePricesPerBuyer": [[]]
        ],
        "nonGuaranteedFixedPriceTerms": ["fixedPrices": [[]]],
        "sellerTimeZone": ""
      ],
      "deliveryControl": [
        "creativeBlockingLevel": "",
        "deliveryRateType": "",
        "frequencyCaps": [
          [
            "maxImpressions": 0,
            "numTimeUnits": 0,
            "timeUnitType": ""
          ]
        ]
      ],
      "description": "",
      "displayName": "",
      "externalDealId": "",
      "isSetupComplete": false,
      "programmaticCreativeSource": "",
      "proposalId": "",
      "sellerContacts": [[]],
      "syndicationProduct": "",
      "targeting": [
        "geoTargeting": [
          "excludedCriteriaIds": [],
          "targetedCriteriaIds": []
        ],
        "inventorySizeTargeting": [
          "excludedInventorySizes": [[]],
          "targetedInventorySizes": [[]]
        ],
        "placementTargeting": [
          "mobileApplicationTargeting": ["firstPartyTargeting": [
              "excludedAppIds": [],
              "targetedAppIds": []
            ]],
          "urlTargeting": [
            "excludedUrls": [],
            "targetedUrls": []
          ]
        ],
        "technologyTargeting": [
          "deviceCapabilityTargeting": [],
          "deviceCategoryTargeting": [],
          "operatingSystemTargeting": [
            "operatingSystemCriteria": [],
            "operatingSystemVersionCriteria": []
          ]
        ],
        "videoTargeting": [
          "excludedPositionTypes": [],
          "targetedPositionTypes": []
        ]
      ],
      "targetingCriterion": [
        [
          "exclusions": [
            [
              "creativeSizeValue": [
                "allowedFormats": [],
                "companionSizes": [
                  [
                    "height": 0,
                    "width": 0
                  ]
                ],
                "creativeSizeType": "",
                "nativeTemplate": "",
                "size": [],
                "skippableAdType": ""
              ],
              "dayPartTargetingValue": [
                "dayParts": [
                  [
                    "dayOfWeek": "",
                    "endTime": [
                      "hours": 0,
                      "minutes": 0,
                      "nanos": 0,
                      "seconds": 0
                    ],
                    "startTime": []
                  ]
                ],
                "timeZoneType": ""
              ],
              "longValue": "",
              "stringValue": ""
            ]
          ],
          "inclusions": [[]],
          "key": ""
        ]
      ],
      "updateTime": "",
      "webPropertyCode": ""
    ]
  ],
  "displayName": "",
  "isRenegotiating": false,
  "isSetupComplete": false,
  "lastUpdaterOrCommentorRole": "",
  "notes": [
    [
      "createTime": "",
      "creatorRole": "",
      "note": "",
      "noteId": "",
      "proposalRevision": ""
    ]
  ],
  "originatorRole": "",
  "privateAuctionId": "",
  "proposalId": "",
  "proposalRevision": "",
  "proposalState": "",
  "seller": [
    "accountId": "",
    "subAccountId": ""
  ],
  "sellerContacts": [[]],
  "termsAndConditions": "",
  "updateTime": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/proposals/:proposalId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET adexchangebuyer2.accounts.publisherProfiles.get
{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId
QUERY PARAMS

accountId
publisherProfileId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId"

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}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId"

	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/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId';
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}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId';
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}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId"]
                                                       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}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId",
  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}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId")

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/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId";

    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}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId
http GET {{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles/:publisherProfileId")! 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 adexchangebuyer2.accounts.publisherProfiles.list
{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles
QUERY PARAMS

accountId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles")
require "http/client"

url = "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles"

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}}/v2beta1/accounts/:accountId/publisherProfiles"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles"

	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/v2beta1/accounts/:accountId/publisherProfiles HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles';
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}}/v2beta1/accounts/:accountId/publisherProfiles',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/accounts/:accountId/publisherProfiles',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles';
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}}/v2beta1/accounts/:accountId/publisherProfiles"]
                                                       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}}/v2beta1/accounts/:accountId/publisherProfiles" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles",
  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}}/v2beta1/accounts/:accountId/publisherProfiles');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/accounts/:accountId/publisherProfiles")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles")

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/v2beta1/accounts/:accountId/publisherProfiles') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles";

    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}}/v2beta1/accounts/:accountId/publisherProfiles
http GET {{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/accounts/:accountId/publisherProfiles")! 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 adexchangebuyer2.bidders.filterSets.bidMetrics.list
{{baseUrl}}/v2beta1/:filterSetName/bidMetrics
QUERY PARAMS

filterSetName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:filterSetName/bidMetrics");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:filterSetName/bidMetrics")
require "http/client"

url = "{{baseUrl}}/v2beta1/:filterSetName/bidMetrics"

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}}/v2beta1/:filterSetName/bidMetrics"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:filterSetName/bidMetrics");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:filterSetName/bidMetrics"

	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/v2beta1/:filterSetName/bidMetrics HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:filterSetName/bidMetrics")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:filterSetName/bidMetrics"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/bidMetrics")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:filterSetName/bidMetrics")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:filterSetName/bidMetrics');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/bidMetrics'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:filterSetName/bidMetrics';
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}}/v2beta1/:filterSetName/bidMetrics',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/bidMetrics")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:filterSetName/bidMetrics',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/bidMetrics'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:filterSetName/bidMetrics');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/bidMetrics'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:filterSetName/bidMetrics';
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}}/v2beta1/:filterSetName/bidMetrics"]
                                                       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}}/v2beta1/:filterSetName/bidMetrics" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:filterSetName/bidMetrics",
  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}}/v2beta1/:filterSetName/bidMetrics');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:filterSetName/bidMetrics');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:filterSetName/bidMetrics');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:filterSetName/bidMetrics' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:filterSetName/bidMetrics' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:filterSetName/bidMetrics")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:filterSetName/bidMetrics"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:filterSetName/bidMetrics"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:filterSetName/bidMetrics")

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/v2beta1/:filterSetName/bidMetrics') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:filterSetName/bidMetrics";

    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}}/v2beta1/:filterSetName/bidMetrics
http GET {{baseUrl}}/v2beta1/:filterSetName/bidMetrics
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:filterSetName/bidMetrics
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:filterSetName/bidMetrics")! 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 adexchangebuyer2.bidders.filterSets.bidResponseErrors.list
{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors
QUERY PARAMS

filterSetName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors")
require "http/client"

url = "{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors"

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}}/v2beta1/:filterSetName/bidResponseErrors"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors"

	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/v2beta1/:filterSetName/bidResponseErrors HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors';
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}}/v2beta1/:filterSetName/bidResponseErrors',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:filterSetName/bidResponseErrors',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors';
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}}/v2beta1/:filterSetName/bidResponseErrors"]
                                                       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}}/v2beta1/:filterSetName/bidResponseErrors" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors",
  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}}/v2beta1/:filterSetName/bidResponseErrors');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:filterSetName/bidResponseErrors")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors")

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/v2beta1/:filterSetName/bidResponseErrors') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors";

    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}}/v2beta1/:filterSetName/bidResponseErrors
http GET {{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:filterSetName/bidResponseErrors")! 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 adexchangebuyer2.bidders.filterSets.bidResponsesWithoutBids.list
{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids
QUERY PARAMS

filterSetName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids")
require "http/client"

url = "{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids"

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}}/v2beta1/:filterSetName/bidResponsesWithoutBids"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids"

	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/v2beta1/:filterSetName/bidResponsesWithoutBids HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids';
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}}/v2beta1/:filterSetName/bidResponsesWithoutBids',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:filterSetName/bidResponsesWithoutBids',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids';
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}}/v2beta1/:filterSetName/bidResponsesWithoutBids"]
                                                       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}}/v2beta1/:filterSetName/bidResponsesWithoutBids" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids",
  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}}/v2beta1/:filterSetName/bidResponsesWithoutBids');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:filterSetName/bidResponsesWithoutBids")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids")

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/v2beta1/:filterSetName/bidResponsesWithoutBids') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids";

    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}}/v2beta1/:filterSetName/bidResponsesWithoutBids
http GET {{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:filterSetName/bidResponsesWithoutBids")! 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 adexchangebuyer2.bidders.filterSets.create
{{baseUrl}}/v2beta1/:ownerName/filterSets
QUERY PARAMS

ownerName
BODY json

{
  "absoluteDateRange": {
    "endDate": {
      "day": 0,
      "month": 0,
      "year": 0
    },
    "startDate": {}
  },
  "breakdownDimensions": [],
  "creativeId": "",
  "dealId": "",
  "environment": "",
  "format": "",
  "formats": [],
  "name": "",
  "platforms": [],
  "publisherIdentifiers": [],
  "realtimeTimeRange": {
    "startTimestamp": ""
  },
  "relativeDateRange": {
    "durationDays": 0,
    "offsetDays": 0
  },
  "sellerNetworkIds": [],
  "timeSeriesGranularity": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:ownerName/filterSets");

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  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v2beta1/:ownerName/filterSets" {:content-type :json
                                                                          :form-params {:absoluteDateRange {:endDate {:day 0
                                                                                                                      :month 0
                                                                                                                      :year 0}
                                                                                                            :startDate {}}
                                                                                        :breakdownDimensions []
                                                                                        :creativeId ""
                                                                                        :dealId ""
                                                                                        :environment ""
                                                                                        :format ""
                                                                                        :formats []
                                                                                        :name ""
                                                                                        :platforms []
                                                                                        :publisherIdentifiers []
                                                                                        :realtimeTimeRange {:startTimestamp ""}
                                                                                        :relativeDateRange {:durationDays 0
                                                                                                            :offsetDays 0}
                                                                                        :sellerNetworkIds []
                                                                                        :timeSeriesGranularity ""}})
require "http/client"

url = "{{baseUrl}}/v2beta1/:ownerName/filterSets"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta1/:ownerName/filterSets"),
    Content = new StringContent("{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:ownerName/filterSets");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:ownerName/filterSets"

	payload := strings.NewReader("{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\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/v2beta1/:ownerName/filterSets HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 493

{
  "absoluteDateRange": {
    "endDate": {
      "day": 0,
      "month": 0,
      "year": 0
    },
    "startDate": {}
  },
  "breakdownDimensions": [],
  "creativeId": "",
  "dealId": "",
  "environment": "",
  "format": "",
  "formats": [],
  "name": "",
  "platforms": [],
  "publisherIdentifiers": [],
  "realtimeTimeRange": {
    "startTimestamp": ""
  },
  "relativeDateRange": {
    "durationDays": 0,
    "offsetDays": 0
  },
  "sellerNetworkIds": [],
  "timeSeriesGranularity": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta1/:ownerName/filterSets")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:ownerName/filterSets"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:ownerName/filterSets")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta1/:ownerName/filterSets")
  .header("content-type", "application/json")
  .body("{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  absoluteDateRange: {
    endDate: {
      day: 0,
      month: 0,
      year: 0
    },
    startDate: {}
  },
  breakdownDimensions: [],
  creativeId: '',
  dealId: '',
  environment: '',
  format: '',
  formats: [],
  name: '',
  platforms: [],
  publisherIdentifiers: [],
  realtimeTimeRange: {
    startTimestamp: ''
  },
  relativeDateRange: {
    durationDays: 0,
    offsetDays: 0
  },
  sellerNetworkIds: [],
  timeSeriesGranularity: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v2beta1/:ownerName/filterSets');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/:ownerName/filterSets',
  headers: {'content-type': 'application/json'},
  data: {
    absoluteDateRange: {endDate: {day: 0, month: 0, year: 0}, startDate: {}},
    breakdownDimensions: [],
    creativeId: '',
    dealId: '',
    environment: '',
    format: '',
    formats: [],
    name: '',
    platforms: [],
    publisherIdentifiers: [],
    realtimeTimeRange: {startTimestamp: ''},
    relativeDateRange: {durationDays: 0, offsetDays: 0},
    sellerNetworkIds: [],
    timeSeriesGranularity: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:ownerName/filterSets';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"absoluteDateRange":{"endDate":{"day":0,"month":0,"year":0},"startDate":{}},"breakdownDimensions":[],"creativeId":"","dealId":"","environment":"","format":"","formats":[],"name":"","platforms":[],"publisherIdentifiers":[],"realtimeTimeRange":{"startTimestamp":""},"relativeDateRange":{"durationDays":0,"offsetDays":0},"sellerNetworkIds":[],"timeSeriesGranularity":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta1/:ownerName/filterSets',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "absoluteDateRange": {\n    "endDate": {\n      "day": 0,\n      "month": 0,\n      "year": 0\n    },\n    "startDate": {}\n  },\n  "breakdownDimensions": [],\n  "creativeId": "",\n  "dealId": "",\n  "environment": "",\n  "format": "",\n  "formats": [],\n  "name": "",\n  "platforms": [],\n  "publisherIdentifiers": [],\n  "realtimeTimeRange": {\n    "startTimestamp": ""\n  },\n  "relativeDateRange": {\n    "durationDays": 0,\n    "offsetDays": 0\n  },\n  "sellerNetworkIds": [],\n  "timeSeriesGranularity": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:ownerName/filterSets")
  .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/v2beta1/:ownerName/filterSets',
  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({
  absoluteDateRange: {endDate: {day: 0, month: 0, year: 0}, startDate: {}},
  breakdownDimensions: [],
  creativeId: '',
  dealId: '',
  environment: '',
  format: '',
  formats: [],
  name: '',
  platforms: [],
  publisherIdentifiers: [],
  realtimeTimeRange: {startTimestamp: ''},
  relativeDateRange: {durationDays: 0, offsetDays: 0},
  sellerNetworkIds: [],
  timeSeriesGranularity: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/:ownerName/filterSets',
  headers: {'content-type': 'application/json'},
  body: {
    absoluteDateRange: {endDate: {day: 0, month: 0, year: 0}, startDate: {}},
    breakdownDimensions: [],
    creativeId: '',
    dealId: '',
    environment: '',
    format: '',
    formats: [],
    name: '',
    platforms: [],
    publisherIdentifiers: [],
    realtimeTimeRange: {startTimestamp: ''},
    relativeDateRange: {durationDays: 0, offsetDays: 0},
    sellerNetworkIds: [],
    timeSeriesGranularity: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v2beta1/:ownerName/filterSets');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  absoluteDateRange: {
    endDate: {
      day: 0,
      month: 0,
      year: 0
    },
    startDate: {}
  },
  breakdownDimensions: [],
  creativeId: '',
  dealId: '',
  environment: '',
  format: '',
  formats: [],
  name: '',
  platforms: [],
  publisherIdentifiers: [],
  realtimeTimeRange: {
    startTimestamp: ''
  },
  relativeDateRange: {
    durationDays: 0,
    offsetDays: 0
  },
  sellerNetworkIds: [],
  timeSeriesGranularity: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta1/:ownerName/filterSets',
  headers: {'content-type': 'application/json'},
  data: {
    absoluteDateRange: {endDate: {day: 0, month: 0, year: 0}, startDate: {}},
    breakdownDimensions: [],
    creativeId: '',
    dealId: '',
    environment: '',
    format: '',
    formats: [],
    name: '',
    platforms: [],
    publisherIdentifiers: [],
    realtimeTimeRange: {startTimestamp: ''},
    relativeDateRange: {durationDays: 0, offsetDays: 0},
    sellerNetworkIds: [],
    timeSeriesGranularity: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:ownerName/filterSets';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"absoluteDateRange":{"endDate":{"day":0,"month":0,"year":0},"startDate":{}},"breakdownDimensions":[],"creativeId":"","dealId":"","environment":"","format":"","formats":[],"name":"","platforms":[],"publisherIdentifiers":[],"realtimeTimeRange":{"startTimestamp":""},"relativeDateRange":{"durationDays":0,"offsetDays":0},"sellerNetworkIds":[],"timeSeriesGranularity":""}'
};

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 = @{ @"absoluteDateRange": @{ @"endDate": @{ @"day": @0, @"month": @0, @"year": @0 }, @"startDate": @{  } },
                              @"breakdownDimensions": @[  ],
                              @"creativeId": @"",
                              @"dealId": @"",
                              @"environment": @"",
                              @"format": @"",
                              @"formats": @[  ],
                              @"name": @"",
                              @"platforms": @[  ],
                              @"publisherIdentifiers": @[  ],
                              @"realtimeTimeRange": @{ @"startTimestamp": @"" },
                              @"relativeDateRange": @{ @"durationDays": @0, @"offsetDays": @0 },
                              @"sellerNetworkIds": @[  ],
                              @"timeSeriesGranularity": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta1/:ownerName/filterSets"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v2beta1/:ownerName/filterSets" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:ownerName/filterSets",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'absoluteDateRange' => [
        'endDate' => [
                'day' => 0,
                'month' => 0,
                'year' => 0
        ],
        'startDate' => [
                
        ]
    ],
    'breakdownDimensions' => [
        
    ],
    'creativeId' => '',
    'dealId' => '',
    'environment' => '',
    'format' => '',
    'formats' => [
        
    ],
    'name' => '',
    'platforms' => [
        
    ],
    'publisherIdentifiers' => [
        
    ],
    'realtimeTimeRange' => [
        'startTimestamp' => ''
    ],
    'relativeDateRange' => [
        'durationDays' => 0,
        'offsetDays' => 0
    ],
    'sellerNetworkIds' => [
        
    ],
    'timeSeriesGranularity' => ''
  ]),
  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}}/v2beta1/:ownerName/filterSets', [
  'body' => '{
  "absoluteDateRange": {
    "endDate": {
      "day": 0,
      "month": 0,
      "year": 0
    },
    "startDate": {}
  },
  "breakdownDimensions": [],
  "creativeId": "",
  "dealId": "",
  "environment": "",
  "format": "",
  "formats": [],
  "name": "",
  "platforms": [],
  "publisherIdentifiers": [],
  "realtimeTimeRange": {
    "startTimestamp": ""
  },
  "relativeDateRange": {
    "durationDays": 0,
    "offsetDays": 0
  },
  "sellerNetworkIds": [],
  "timeSeriesGranularity": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:ownerName/filterSets');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'absoluteDateRange' => [
    'endDate' => [
        'day' => 0,
        'month' => 0,
        'year' => 0
    ],
    'startDate' => [
        
    ]
  ],
  'breakdownDimensions' => [
    
  ],
  'creativeId' => '',
  'dealId' => '',
  'environment' => '',
  'format' => '',
  'formats' => [
    
  ],
  'name' => '',
  'platforms' => [
    
  ],
  'publisherIdentifiers' => [
    
  ],
  'realtimeTimeRange' => [
    'startTimestamp' => ''
  ],
  'relativeDateRange' => [
    'durationDays' => 0,
    'offsetDays' => 0
  ],
  'sellerNetworkIds' => [
    
  ],
  'timeSeriesGranularity' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'absoluteDateRange' => [
    'endDate' => [
        'day' => 0,
        'month' => 0,
        'year' => 0
    ],
    'startDate' => [
        
    ]
  ],
  'breakdownDimensions' => [
    
  ],
  'creativeId' => '',
  'dealId' => '',
  'environment' => '',
  'format' => '',
  'formats' => [
    
  ],
  'name' => '',
  'platforms' => [
    
  ],
  'publisherIdentifiers' => [
    
  ],
  'realtimeTimeRange' => [
    'startTimestamp' => ''
  ],
  'relativeDateRange' => [
    'durationDays' => 0,
    'offsetDays' => 0
  ],
  'sellerNetworkIds' => [
    
  ],
  'timeSeriesGranularity' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v2beta1/:ownerName/filterSets');
$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}}/v2beta1/:ownerName/filterSets' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "absoluteDateRange": {
    "endDate": {
      "day": 0,
      "month": 0,
      "year": 0
    },
    "startDate": {}
  },
  "breakdownDimensions": [],
  "creativeId": "",
  "dealId": "",
  "environment": "",
  "format": "",
  "formats": [],
  "name": "",
  "platforms": [],
  "publisherIdentifiers": [],
  "realtimeTimeRange": {
    "startTimestamp": ""
  },
  "relativeDateRange": {
    "durationDays": 0,
    "offsetDays": 0
  },
  "sellerNetworkIds": [],
  "timeSeriesGranularity": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:ownerName/filterSets' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "absoluteDateRange": {
    "endDate": {
      "day": 0,
      "month": 0,
      "year": 0
    },
    "startDate": {}
  },
  "breakdownDimensions": [],
  "creativeId": "",
  "dealId": "",
  "environment": "",
  "format": "",
  "formats": [],
  "name": "",
  "platforms": [],
  "publisherIdentifiers": [],
  "realtimeTimeRange": {
    "startTimestamp": ""
  },
  "relativeDateRange": {
    "durationDays": 0,
    "offsetDays": 0
  },
  "sellerNetworkIds": [],
  "timeSeriesGranularity": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v2beta1/:ownerName/filterSets", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:ownerName/filterSets"

payload = {
    "absoluteDateRange": {
        "endDate": {
            "day": 0,
            "month": 0,
            "year": 0
        },
        "startDate": {}
    },
    "breakdownDimensions": [],
    "creativeId": "",
    "dealId": "",
    "environment": "",
    "format": "",
    "formats": [],
    "name": "",
    "platforms": [],
    "publisherIdentifiers": [],
    "realtimeTimeRange": { "startTimestamp": "" },
    "relativeDateRange": {
        "durationDays": 0,
        "offsetDays": 0
    },
    "sellerNetworkIds": [],
    "timeSeriesGranularity": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:ownerName/filterSets"

payload <- "{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\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}}/v2beta1/:ownerName/filterSets")

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  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v2beta1/:ownerName/filterSets') do |req|
  req.body = "{\n  \"absoluteDateRange\": {\n    \"endDate\": {\n      \"day\": 0,\n      \"month\": 0,\n      \"year\": 0\n    },\n    \"startDate\": {}\n  },\n  \"breakdownDimensions\": [],\n  \"creativeId\": \"\",\n  \"dealId\": \"\",\n  \"environment\": \"\",\n  \"format\": \"\",\n  \"formats\": [],\n  \"name\": \"\",\n  \"platforms\": [],\n  \"publisherIdentifiers\": [],\n  \"realtimeTimeRange\": {\n    \"startTimestamp\": \"\"\n  },\n  \"relativeDateRange\": {\n    \"durationDays\": 0,\n    \"offsetDays\": 0\n  },\n  \"sellerNetworkIds\": [],\n  \"timeSeriesGranularity\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:ownerName/filterSets";

    let payload = json!({
        "absoluteDateRange": json!({
            "endDate": json!({
                "day": 0,
                "month": 0,
                "year": 0
            }),
            "startDate": json!({})
        }),
        "breakdownDimensions": (),
        "creativeId": "",
        "dealId": "",
        "environment": "",
        "format": "",
        "formats": (),
        "name": "",
        "platforms": (),
        "publisherIdentifiers": (),
        "realtimeTimeRange": json!({"startTimestamp": ""}),
        "relativeDateRange": json!({
            "durationDays": 0,
            "offsetDays": 0
        }),
        "sellerNetworkIds": (),
        "timeSeriesGranularity": ""
    });

    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}}/v2beta1/:ownerName/filterSets \
  --header 'content-type: application/json' \
  --data '{
  "absoluteDateRange": {
    "endDate": {
      "day": 0,
      "month": 0,
      "year": 0
    },
    "startDate": {}
  },
  "breakdownDimensions": [],
  "creativeId": "",
  "dealId": "",
  "environment": "",
  "format": "",
  "formats": [],
  "name": "",
  "platforms": [],
  "publisherIdentifiers": [],
  "realtimeTimeRange": {
    "startTimestamp": ""
  },
  "relativeDateRange": {
    "durationDays": 0,
    "offsetDays": 0
  },
  "sellerNetworkIds": [],
  "timeSeriesGranularity": ""
}'
echo '{
  "absoluteDateRange": {
    "endDate": {
      "day": 0,
      "month": 0,
      "year": 0
    },
    "startDate": {}
  },
  "breakdownDimensions": [],
  "creativeId": "",
  "dealId": "",
  "environment": "",
  "format": "",
  "formats": [],
  "name": "",
  "platforms": [],
  "publisherIdentifiers": [],
  "realtimeTimeRange": {
    "startTimestamp": ""
  },
  "relativeDateRange": {
    "durationDays": 0,
    "offsetDays": 0
  },
  "sellerNetworkIds": [],
  "timeSeriesGranularity": ""
}' |  \
  http POST {{baseUrl}}/v2beta1/:ownerName/filterSets \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "absoluteDateRange": {\n    "endDate": {\n      "day": 0,\n      "month": 0,\n      "year": 0\n    },\n    "startDate": {}\n  },\n  "breakdownDimensions": [],\n  "creativeId": "",\n  "dealId": "",\n  "environment": "",\n  "format": "",\n  "formats": [],\n  "name": "",\n  "platforms": [],\n  "publisherIdentifiers": [],\n  "realtimeTimeRange": {\n    "startTimestamp": ""\n  },\n  "relativeDateRange": {\n    "durationDays": 0,\n    "offsetDays": 0\n  },\n  "sellerNetworkIds": [],\n  "timeSeriesGranularity": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta1/:ownerName/filterSets
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "absoluteDateRange": [
    "endDate": [
      "day": 0,
      "month": 0,
      "year": 0
    ],
    "startDate": []
  ],
  "breakdownDimensions": [],
  "creativeId": "",
  "dealId": "",
  "environment": "",
  "format": "",
  "formats": [],
  "name": "",
  "platforms": [],
  "publisherIdentifiers": [],
  "realtimeTimeRange": ["startTimestamp": ""],
  "relativeDateRange": [
    "durationDays": 0,
    "offsetDays": 0
  ],
  "sellerNetworkIds": [],
  "timeSeriesGranularity": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:ownerName/filterSets")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as 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 adexchangebuyer2.bidders.filterSets.delete
{{baseUrl}}/v2beta1/:name
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:name");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/v2beta1/:name")
require "http/client"

url = "{{baseUrl}}/v2beta1/:name"

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}}/v2beta1/:name"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:name");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:name"

	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/v2beta1/:name HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/v2beta1/:name")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:name"))
    .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}}/v2beta1/:name")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/v2beta1/:name")
  .asString();
const 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}}/v2beta1/:name');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/v2beta1/:name'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:name';
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}}/v2beta1/:name',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:name")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:name',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/v2beta1/:name'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/v2beta1/:name');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'DELETE', url: '{{baseUrl}}/v2beta1/:name'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:name';
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}}/v2beta1/:name"]
                                                       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}}/v2beta1/:name" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:name",
  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}}/v2beta1/:name');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:name');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:name');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:name' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:name' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/v2beta1/:name")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:name"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:name"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:name")

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/v2beta1/:name') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:name";

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("DELETE").unwrap(), url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request DELETE \
  --url {{baseUrl}}/v2beta1/:name
http DELETE {{baseUrl}}/v2beta1/:name
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/v2beta1/:name
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:name")! 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 adexchangebuyer2.bidders.filterSets.filteredBidRequests.list
{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests
QUERY PARAMS

filterSetName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests")
require "http/client"

url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests"

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}}/v2beta1/:filterSetName/filteredBidRequests"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests"

	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/v2beta1/:filterSetName/filteredBidRequests HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests';
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}}/v2beta1/:filterSetName/filteredBidRequests',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:filterSetName/filteredBidRequests',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests';
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}}/v2beta1/:filterSetName/filteredBidRequests"]
                                                       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}}/v2beta1/:filterSetName/filteredBidRequests" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests",
  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}}/v2beta1/:filterSetName/filteredBidRequests');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:filterSetName/filteredBidRequests")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests")

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/v2beta1/:filterSetName/filteredBidRequests') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests";

    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}}/v2beta1/:filterSetName/filteredBidRequests
http GET {{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:filterSetName/filteredBidRequests")! 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 adexchangebuyer2.bidders.filterSets.filteredBids.creatives.list
{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives
QUERY PARAMS

filterSetName
creativeStatusId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives")
require "http/client"

url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives"

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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives"

	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/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives';
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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives';
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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives"]
                                                       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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives",
  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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives")

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/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives";

    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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives
http GET {{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/creatives")! 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 adexchangebuyer2.bidders.filterSets.filteredBids.details.list
{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details
QUERY PARAMS

filterSetName
creativeStatusId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details")
require "http/client"

url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details"

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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details"

	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/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details';
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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details';
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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details"]
                                                       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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details",
  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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details")

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/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details";

    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}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details
http GET {{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:filterSetName/filteredBids/:creativeStatusId/details")! 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 adexchangebuyer2.bidders.filterSets.filteredBids.list
{{baseUrl}}/v2beta1/:filterSetName/filteredBids
QUERY PARAMS

filterSetName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:filterSetName/filteredBids");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:filterSetName/filteredBids")
require "http/client"

url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBids"

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}}/v2beta1/:filterSetName/filteredBids"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:filterSetName/filteredBids");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:filterSetName/filteredBids"

	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/v2beta1/:filterSetName/filteredBids HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:filterSetName/filteredBids")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:filterSetName/filteredBids"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/filteredBids")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:filterSetName/filteredBids")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:filterSetName/filteredBids');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBids'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:filterSetName/filteredBids';
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}}/v2beta1/:filterSetName/filteredBids',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/filteredBids")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:filterSetName/filteredBids',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBids'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:filterSetName/filteredBids');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/filteredBids'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:filterSetName/filteredBids';
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}}/v2beta1/:filterSetName/filteredBids"]
                                                       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}}/v2beta1/:filterSetName/filteredBids" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:filterSetName/filteredBids",
  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}}/v2beta1/:filterSetName/filteredBids');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:filterSetName/filteredBids');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:filterSetName/filteredBids');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:filterSetName/filteredBids' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:filterSetName/filteredBids' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:filterSetName/filteredBids")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBids"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:filterSetName/filteredBids"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:filterSetName/filteredBids")

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/v2beta1/:filterSetName/filteredBids') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:filterSetName/filteredBids";

    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}}/v2beta1/:filterSetName/filteredBids
http GET {{baseUrl}}/v2beta1/:filterSetName/filteredBids
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:filterSetName/filteredBids
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:filterSetName/filteredBids")! 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 adexchangebuyer2.bidders.filterSets.get
{{baseUrl}}/v2beta1/:name
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:name");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:name")
require "http/client"

url = "{{baseUrl}}/v2beta1/:name"

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}}/v2beta1/:name"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:name");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:name"

	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/v2beta1/:name HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:name")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:name"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:name")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:name")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:name');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/v2beta1/:name'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:name';
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}}/v2beta1/:name',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:name")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:name',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/v2beta1/:name'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:name');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/v2beta1/:name'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:name';
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}}/v2beta1/:name"]
                                                       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}}/v2beta1/:name" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:name",
  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}}/v2beta1/:name');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:name');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:name');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:name' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:name' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:name")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:name"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:name"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:name")

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/v2beta1/:name') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:name";

    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}}/v2beta1/:name
http GET {{baseUrl}}/v2beta1/:name
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:name
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:name")! 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 adexchangebuyer2.bidders.filterSets.impressionMetrics.list
{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics
QUERY PARAMS

filterSetName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics")
require "http/client"

url = "{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics"

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}}/v2beta1/:filterSetName/impressionMetrics"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics"

	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/v2beta1/:filterSetName/impressionMetrics HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics';
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}}/v2beta1/:filterSetName/impressionMetrics',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:filterSetName/impressionMetrics',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics';
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}}/v2beta1/:filterSetName/impressionMetrics"]
                                                       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}}/v2beta1/:filterSetName/impressionMetrics" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics",
  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}}/v2beta1/:filterSetName/impressionMetrics');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:filterSetName/impressionMetrics")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics")

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/v2beta1/:filterSetName/impressionMetrics') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics";

    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}}/v2beta1/:filterSetName/impressionMetrics
http GET {{baseUrl}}/v2beta1/:filterSetName/impressionMetrics
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:filterSetName/impressionMetrics
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:filterSetName/impressionMetrics")! 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 adexchangebuyer2.bidders.filterSets.list
{{baseUrl}}/v2beta1/:ownerName/filterSets
QUERY PARAMS

ownerName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:ownerName/filterSets");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:ownerName/filterSets")
require "http/client"

url = "{{baseUrl}}/v2beta1/:ownerName/filterSets"

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}}/v2beta1/:ownerName/filterSets"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:ownerName/filterSets");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:ownerName/filterSets"

	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/v2beta1/:ownerName/filterSets HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:ownerName/filterSets")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:ownerName/filterSets"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:ownerName/filterSets")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:ownerName/filterSets")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:ownerName/filterSets');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:ownerName/filterSets'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:ownerName/filterSets';
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}}/v2beta1/:ownerName/filterSets',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:ownerName/filterSets")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:ownerName/filterSets',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:ownerName/filterSets'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:ownerName/filterSets');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:ownerName/filterSets'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:ownerName/filterSets';
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}}/v2beta1/:ownerName/filterSets"]
                                                       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}}/v2beta1/:ownerName/filterSets" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:ownerName/filterSets",
  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}}/v2beta1/:ownerName/filterSets');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:ownerName/filterSets');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:ownerName/filterSets');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:ownerName/filterSets' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:ownerName/filterSets' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:ownerName/filterSets")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:ownerName/filterSets"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:ownerName/filterSets"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:ownerName/filterSets")

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/v2beta1/:ownerName/filterSets') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:ownerName/filterSets";

    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}}/v2beta1/:ownerName/filterSets
http GET {{baseUrl}}/v2beta1/:ownerName/filterSets
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:ownerName/filterSets
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:ownerName/filterSets")! 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 adexchangebuyer2.bidders.filterSets.losingBids.list
{{baseUrl}}/v2beta1/:filterSetName/losingBids
QUERY PARAMS

filterSetName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:filterSetName/losingBids");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:filterSetName/losingBids")
require "http/client"

url = "{{baseUrl}}/v2beta1/:filterSetName/losingBids"

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}}/v2beta1/:filterSetName/losingBids"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:filterSetName/losingBids");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:filterSetName/losingBids"

	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/v2beta1/:filterSetName/losingBids HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:filterSetName/losingBids")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:filterSetName/losingBids"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/losingBids")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:filterSetName/losingBids")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:filterSetName/losingBids');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/losingBids'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:filterSetName/losingBids';
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}}/v2beta1/:filterSetName/losingBids',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/losingBids")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:filterSetName/losingBids',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/losingBids'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:filterSetName/losingBids');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/losingBids'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:filterSetName/losingBids';
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}}/v2beta1/:filterSetName/losingBids"]
                                                       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}}/v2beta1/:filterSetName/losingBids" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:filterSetName/losingBids",
  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}}/v2beta1/:filterSetName/losingBids');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:filterSetName/losingBids');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:filterSetName/losingBids');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:filterSetName/losingBids' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:filterSetName/losingBids' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:filterSetName/losingBids")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:filterSetName/losingBids"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:filterSetName/losingBids"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:filterSetName/losingBids")

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/v2beta1/:filterSetName/losingBids') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:filterSetName/losingBids";

    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}}/v2beta1/:filterSetName/losingBids
http GET {{baseUrl}}/v2beta1/:filterSetName/losingBids
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:filterSetName/losingBids
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:filterSetName/losingBids")! 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 adexchangebuyer2.bidders.filterSets.nonBillableWinningBids.list
{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids
QUERY PARAMS

filterSetName
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids")
require "http/client"

url = "{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids"

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}}/v2beta1/:filterSetName/nonBillableWinningBids"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids"

	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/v2beta1/:filterSetName/nonBillableWinningBids HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids';
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}}/v2beta1/:filterSetName/nonBillableWinningBids',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v2beta1/:filterSetName/nonBillableWinningBids',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids';
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}}/v2beta1/:filterSetName/nonBillableWinningBids"]
                                                       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}}/v2beta1/:filterSetName/nonBillableWinningBids" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids",
  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}}/v2beta1/:filterSetName/nonBillableWinningBids');

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v2beta1/:filterSetName/nonBillableWinningBids")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids")

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/v2beta1/:filterSetName/nonBillableWinningBids') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids";

    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}}/v2beta1/:filterSetName/nonBillableWinningBids
http GET {{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta1/:filterSetName/nonBillableWinningBids")! 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()