POST jobs.projects.clientEvents.create
{{baseUrl}}/v3p1beta1/:parent/clientEvents
QUERY PARAMS

parent
BODY json

{
  "clientEvent": {
    "createTime": "",
    "eventId": "",
    "extraInfo": {},
    "jobEvent": {
      "jobs": [],
      "type": ""
    },
    "parentEventId": "",
    "requestId": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3p1beta1/:parent/clientEvents");

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  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\n  }\n}");

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

(client/post "{{baseUrl}}/v3p1beta1/:parent/clientEvents" {:content-type :json
                                                                           :form-params {:clientEvent {:createTime ""
                                                                                                       :eventId ""
                                                                                                       :extraInfo {}
                                                                                                       :jobEvent {:jobs []
                                                                                                                  :type ""}
                                                                                                       :parentEventId ""
                                                                                                       :requestId ""}}})
require "http/client"

url = "{{baseUrl}}/v3p1beta1/:parent/clientEvents"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\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}}/v3p1beta1/:parent/clientEvents"),
    Content = new StringContent("{\n  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\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}}/v3p1beta1/:parent/clientEvents");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/:parent/clientEvents"

	payload := strings.NewReader("{\n  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\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/v3p1beta1/:parent/clientEvents HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 193

{
  "clientEvent": {
    "createTime": "",
    "eventId": "",
    "extraInfo": {},
    "jobEvent": {
      "jobs": [],
      "type": ""
    },
    "parentEventId": "",
    "requestId": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3p1beta1/:parent/clientEvents")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3p1beta1/:parent/clientEvents"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\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  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/clientEvents")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3p1beta1/:parent/clientEvents")
  .header("content-type", "application/json")
  .body("{\n  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  clientEvent: {
    createTime: '',
    eventId: '',
    extraInfo: {},
    jobEvent: {
      jobs: [],
      type: ''
    },
    parentEventId: '',
    requestId: ''
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/v3p1beta1/:parent/clientEvents');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/clientEvents',
  headers: {'content-type': 'application/json'},
  data: {
    clientEvent: {
      createTime: '',
      eventId: '',
      extraInfo: {},
      jobEvent: {jobs: [], type: ''},
      parentEventId: '',
      requestId: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3p1beta1/:parent/clientEvents';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clientEvent":{"createTime":"","eventId":"","extraInfo":{},"jobEvent":{"jobs":[],"type":""},"parentEventId":"","requestId":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v3p1beta1/:parent/clientEvents',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clientEvent": {\n    "createTime": "",\n    "eventId": "",\n    "extraInfo": {},\n    "jobEvent": {\n      "jobs": [],\n      "type": ""\n    },\n    "parentEventId": "",\n    "requestId": ""\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  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/clientEvents")
  .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/v3p1beta1/:parent/clientEvents',
  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({
  clientEvent: {
    createTime: '',
    eventId: '',
    extraInfo: {},
    jobEvent: {jobs: [], type: ''},
    parentEventId: '',
    requestId: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/clientEvents',
  headers: {'content-type': 'application/json'},
  body: {
    clientEvent: {
      createTime: '',
      eventId: '',
      extraInfo: {},
      jobEvent: {jobs: [], type: ''},
      parentEventId: '',
      requestId: ''
    }
  },
  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}}/v3p1beta1/:parent/clientEvents');

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

req.type('json');
req.send({
  clientEvent: {
    createTime: '',
    eventId: '',
    extraInfo: {},
    jobEvent: {
      jobs: [],
      type: ''
    },
    parentEventId: '',
    requestId: ''
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/clientEvents',
  headers: {'content-type': 'application/json'},
  data: {
    clientEvent: {
      createTime: '',
      eventId: '',
      extraInfo: {},
      jobEvent: {jobs: [], type: ''},
      parentEventId: '',
      requestId: ''
    }
  }
};

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

const url = '{{baseUrl}}/v3p1beta1/:parent/clientEvents';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clientEvent":{"createTime":"","eventId":"","extraInfo":{},"jobEvent":{"jobs":[],"type":""},"parentEventId":"","requestId":""}}'
};

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 = @{ @"clientEvent": @{ @"createTime": @"", @"eventId": @"", @"extraInfo": @{  }, @"jobEvent": @{ @"jobs": @[  ], @"type": @"" }, @"parentEventId": @"", @"requestId": @"" } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3p1beta1/:parent/clientEvents"]
                                                       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}}/v3p1beta1/:parent/clientEvents" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3p1beta1/:parent/clientEvents",
  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([
    'clientEvent' => [
        'createTime' => '',
        'eventId' => '',
        'extraInfo' => [
                
        ],
        'jobEvent' => [
                'jobs' => [
                                
                ],
                'type' => ''
        ],
        'parentEventId' => '',
        'requestId' => ''
    ]
  ]),
  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}}/v3p1beta1/:parent/clientEvents', [
  'body' => '{
  "clientEvent": {
    "createTime": "",
    "eventId": "",
    "extraInfo": {},
    "jobEvent": {
      "jobs": [],
      "type": ""
    },
    "parentEventId": "",
    "requestId": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3p1beta1/:parent/clientEvents');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clientEvent' => [
    'createTime' => '',
    'eventId' => '',
    'extraInfo' => [
        
    ],
    'jobEvent' => [
        'jobs' => [
                
        ],
        'type' => ''
    ],
    'parentEventId' => '',
    'requestId' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clientEvent' => [
    'createTime' => '',
    'eventId' => '',
    'extraInfo' => [
        
    ],
    'jobEvent' => [
        'jobs' => [
                
        ],
        'type' => ''
    ],
    'parentEventId' => '',
    'requestId' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3p1beta1/:parent/clientEvents');
$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}}/v3p1beta1/:parent/clientEvents' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clientEvent": {
    "createTime": "",
    "eventId": "",
    "extraInfo": {},
    "jobEvent": {
      "jobs": [],
      "type": ""
    },
    "parentEventId": "",
    "requestId": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3p1beta1/:parent/clientEvents' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clientEvent": {
    "createTime": "",
    "eventId": "",
    "extraInfo": {},
    "jobEvent": {
      "jobs": [],
      "type": ""
    },
    "parentEventId": "",
    "requestId": ""
  }
}'
import http.client

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

payload = "{\n  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\n  }\n}"

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

conn.request("POST", "/baseUrl/v3p1beta1/:parent/clientEvents", payload, headers)

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

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

url = "{{baseUrl}}/v3p1beta1/:parent/clientEvents"

payload = { "clientEvent": {
        "createTime": "",
        "eventId": "",
        "extraInfo": {},
        "jobEvent": {
            "jobs": [],
            "type": ""
        },
        "parentEventId": "",
        "requestId": ""
    } }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3p1beta1/:parent/clientEvents"

payload <- "{\n  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\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}}/v3p1beta1/:parent/clientEvents")

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  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\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/v3p1beta1/:parent/clientEvents') do |req|
  req.body = "{\n  \"clientEvent\": {\n    \"createTime\": \"\",\n    \"eventId\": \"\",\n    \"extraInfo\": {},\n    \"jobEvent\": {\n      \"jobs\": [],\n      \"type\": \"\"\n    },\n    \"parentEventId\": \"\",\n    \"requestId\": \"\"\n  }\n}"
end

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

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

    let payload = json!({"clientEvent": json!({
            "createTime": "",
            "eventId": "",
            "extraInfo": json!({}),
            "jobEvent": json!({
                "jobs": (),
                "type": ""
            }),
            "parentEventId": "",
            "requestId": ""
        })});

    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}}/v3p1beta1/:parent/clientEvents \
  --header 'content-type: application/json' \
  --data '{
  "clientEvent": {
    "createTime": "",
    "eventId": "",
    "extraInfo": {},
    "jobEvent": {
      "jobs": [],
      "type": ""
    },
    "parentEventId": "",
    "requestId": ""
  }
}'
echo '{
  "clientEvent": {
    "createTime": "",
    "eventId": "",
    "extraInfo": {},
    "jobEvent": {
      "jobs": [],
      "type": ""
    },
    "parentEventId": "",
    "requestId": ""
  }
}' |  \
  http POST {{baseUrl}}/v3p1beta1/:parent/clientEvents \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clientEvent": {\n    "createTime": "",\n    "eventId": "",\n    "extraInfo": {},\n    "jobEvent": {\n      "jobs": [],\n      "type": ""\n    },\n    "parentEventId": "",\n    "requestId": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:parent/clientEvents
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["clientEvent": [
    "createTime": "",
    "eventId": "",
    "extraInfo": [],
    "jobEvent": [
      "jobs": [],
      "type": ""
    ],
    "parentEventId": "",
    "requestId": ""
  ]] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3p1beta1/:parent/clientEvents")! 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 jobs.projects.companies.create
{{baseUrl}}/v3p1beta1/:parent/companies
QUERY PARAMS

parent
BODY json

{
  "company": {
    "careerSiteUri": "",
    "derivedInfo": {
      "headquartersLocation": {
        "latLng": {
          "latitude": "",
          "longitude": ""
        },
        "locationType": "",
        "postalAddress": {
          "addressLines": [],
          "administrativeArea": "",
          "languageCode": "",
          "locality": "",
          "organization": "",
          "postalCode": "",
          "recipients": [],
          "regionCode": "",
          "revision": 0,
          "sortingCode": "",
          "sublocality": ""
        },
        "radiusInMiles": ""
      }
    },
    "displayName": "",
    "eeoText": "",
    "externalId": "",
    "headquartersAddress": "",
    "hiringAgency": false,
    "imageUri": "",
    "keywordSearchableJobCustomAttributes": [],
    "name": "",
    "size": "",
    "suspended": false,
    "websiteUri": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3p1beta1/:parent/companies");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\n  }\n}");

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

(client/post "{{baseUrl}}/v3p1beta1/:parent/companies" {:content-type :json
                                                                        :form-params {:company {:careerSiteUri ""
                                                                                                :derivedInfo {:headquartersLocation {:latLng {:latitude ""
                                                                                                                                              :longitude ""}
                                                                                                                                     :locationType ""
                                                                                                                                     :postalAddress {:addressLines []
                                                                                                                                                     :administrativeArea ""
                                                                                                                                                     :languageCode ""
                                                                                                                                                     :locality ""
                                                                                                                                                     :organization ""
                                                                                                                                                     :postalCode ""
                                                                                                                                                     :recipients []
                                                                                                                                                     :regionCode ""
                                                                                                                                                     :revision 0
                                                                                                                                                     :sortingCode ""
                                                                                                                                                     :sublocality ""}
                                                                                                                                     :radiusInMiles ""}}
                                                                                                :displayName ""
                                                                                                :eeoText ""
                                                                                                :externalId ""
                                                                                                :headquartersAddress ""
                                                                                                :hiringAgency false
                                                                                                :imageUri ""
                                                                                                :keywordSearchableJobCustomAttributes []
                                                                                                :name ""
                                                                                                :size ""
                                                                                                :suspended false
                                                                                                :websiteUri ""}}})
require "http/client"

url = "{{baseUrl}}/v3p1beta1/:parent/companies"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\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}}/v3p1beta1/:parent/companies"),
    Content = new StringContent("{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\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}}/v3p1beta1/:parent/companies");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/:parent/companies"

	payload := strings.NewReader("{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\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/v3p1beta1/:parent/companies HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 877

{
  "company": {
    "careerSiteUri": "",
    "derivedInfo": {
      "headquartersLocation": {
        "latLng": {
          "latitude": "",
          "longitude": ""
        },
        "locationType": "",
        "postalAddress": {
          "addressLines": [],
          "administrativeArea": "",
          "languageCode": "",
          "locality": "",
          "organization": "",
          "postalCode": "",
          "recipients": [],
          "regionCode": "",
          "revision": 0,
          "sortingCode": "",
          "sublocality": ""
        },
        "radiusInMiles": ""
      }
    },
    "displayName": "",
    "eeoText": "",
    "externalId": "",
    "headquartersAddress": "",
    "hiringAgency": false,
    "imageUri": "",
    "keywordSearchableJobCustomAttributes": [],
    "name": "",
    "size": "",
    "suspended": false,
    "websiteUri": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3p1beta1/:parent/companies")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3p1beta1/:parent/companies"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/companies")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3p1beta1/:parent/companies")
  .header("content-type", "application/json")
  .body("{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  company: {
    careerSiteUri: '',
    derivedInfo: {
      headquartersLocation: {
        latLng: {
          latitude: '',
          longitude: ''
        },
        locationType: '',
        postalAddress: {
          addressLines: [],
          administrativeArea: '',
          languageCode: '',
          locality: '',
          organization: '',
          postalCode: '',
          recipients: [],
          regionCode: '',
          revision: 0,
          sortingCode: '',
          sublocality: ''
        },
        radiusInMiles: ''
      }
    },
    displayName: '',
    eeoText: '',
    externalId: '',
    headquartersAddress: '',
    hiringAgency: false,
    imageUri: '',
    keywordSearchableJobCustomAttributes: [],
    name: '',
    size: '',
    suspended: false,
    websiteUri: ''
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/v3p1beta1/:parent/companies');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/companies',
  headers: {'content-type': 'application/json'},
  data: {
    company: {
      careerSiteUri: '',
      derivedInfo: {
        headquartersLocation: {
          latLng: {latitude: '', longitude: ''},
          locationType: '',
          postalAddress: {
            addressLines: [],
            administrativeArea: '',
            languageCode: '',
            locality: '',
            organization: '',
            postalCode: '',
            recipients: [],
            regionCode: '',
            revision: 0,
            sortingCode: '',
            sublocality: ''
          },
          radiusInMiles: ''
        }
      },
      displayName: '',
      eeoText: '',
      externalId: '',
      headquartersAddress: '',
      hiringAgency: false,
      imageUri: '',
      keywordSearchableJobCustomAttributes: [],
      name: '',
      size: '',
      suspended: false,
      websiteUri: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3p1beta1/:parent/companies';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"company":{"careerSiteUri":"","derivedInfo":{"headquartersLocation":{"latLng":{"latitude":"","longitude":""},"locationType":"","postalAddress":{"addressLines":[],"administrativeArea":"","languageCode":"","locality":"","organization":"","postalCode":"","recipients":[],"regionCode":"","revision":0,"sortingCode":"","sublocality":""},"radiusInMiles":""}},"displayName":"","eeoText":"","externalId":"","headquartersAddress":"","hiringAgency":false,"imageUri":"","keywordSearchableJobCustomAttributes":[],"name":"","size":"","suspended":false,"websiteUri":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v3p1beta1/:parent/companies',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "company": {\n    "careerSiteUri": "",\n    "derivedInfo": {\n      "headquartersLocation": {\n        "latLng": {\n          "latitude": "",\n          "longitude": ""\n        },\n        "locationType": "",\n        "postalAddress": {\n          "addressLines": [],\n          "administrativeArea": "",\n          "languageCode": "",\n          "locality": "",\n          "organization": "",\n          "postalCode": "",\n          "recipients": [],\n          "regionCode": "",\n          "revision": 0,\n          "sortingCode": "",\n          "sublocality": ""\n        },\n        "radiusInMiles": ""\n      }\n    },\n    "displayName": "",\n    "eeoText": "",\n    "externalId": "",\n    "headquartersAddress": "",\n    "hiringAgency": false,\n    "imageUri": "",\n    "keywordSearchableJobCustomAttributes": [],\n    "name": "",\n    "size": "",\n    "suspended": false,\n    "websiteUri": ""\n  }\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/companies")
  .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/v3p1beta1/:parent/companies',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  company: {
    careerSiteUri: '',
    derivedInfo: {
      headquartersLocation: {
        latLng: {latitude: '', longitude: ''},
        locationType: '',
        postalAddress: {
          addressLines: [],
          administrativeArea: '',
          languageCode: '',
          locality: '',
          organization: '',
          postalCode: '',
          recipients: [],
          regionCode: '',
          revision: 0,
          sortingCode: '',
          sublocality: ''
        },
        radiusInMiles: ''
      }
    },
    displayName: '',
    eeoText: '',
    externalId: '',
    headquartersAddress: '',
    hiringAgency: false,
    imageUri: '',
    keywordSearchableJobCustomAttributes: [],
    name: '',
    size: '',
    suspended: false,
    websiteUri: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/companies',
  headers: {'content-type': 'application/json'},
  body: {
    company: {
      careerSiteUri: '',
      derivedInfo: {
        headquartersLocation: {
          latLng: {latitude: '', longitude: ''},
          locationType: '',
          postalAddress: {
            addressLines: [],
            administrativeArea: '',
            languageCode: '',
            locality: '',
            organization: '',
            postalCode: '',
            recipients: [],
            regionCode: '',
            revision: 0,
            sortingCode: '',
            sublocality: ''
          },
          radiusInMiles: ''
        }
      },
      displayName: '',
      eeoText: '',
      externalId: '',
      headquartersAddress: '',
      hiringAgency: false,
      imageUri: '',
      keywordSearchableJobCustomAttributes: [],
      name: '',
      size: '',
      suspended: false,
      websiteUri: ''
    }
  },
  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}}/v3p1beta1/:parent/companies');

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

req.type('json');
req.send({
  company: {
    careerSiteUri: '',
    derivedInfo: {
      headquartersLocation: {
        latLng: {
          latitude: '',
          longitude: ''
        },
        locationType: '',
        postalAddress: {
          addressLines: [],
          administrativeArea: '',
          languageCode: '',
          locality: '',
          organization: '',
          postalCode: '',
          recipients: [],
          regionCode: '',
          revision: 0,
          sortingCode: '',
          sublocality: ''
        },
        radiusInMiles: ''
      }
    },
    displayName: '',
    eeoText: '',
    externalId: '',
    headquartersAddress: '',
    hiringAgency: false,
    imageUri: '',
    keywordSearchableJobCustomAttributes: [],
    name: '',
    size: '',
    suspended: false,
    websiteUri: ''
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/companies',
  headers: {'content-type': 'application/json'},
  data: {
    company: {
      careerSiteUri: '',
      derivedInfo: {
        headquartersLocation: {
          latLng: {latitude: '', longitude: ''},
          locationType: '',
          postalAddress: {
            addressLines: [],
            administrativeArea: '',
            languageCode: '',
            locality: '',
            organization: '',
            postalCode: '',
            recipients: [],
            regionCode: '',
            revision: 0,
            sortingCode: '',
            sublocality: ''
          },
          radiusInMiles: ''
        }
      },
      displayName: '',
      eeoText: '',
      externalId: '',
      headquartersAddress: '',
      hiringAgency: false,
      imageUri: '',
      keywordSearchableJobCustomAttributes: [],
      name: '',
      size: '',
      suspended: false,
      websiteUri: ''
    }
  }
};

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

const url = '{{baseUrl}}/v3p1beta1/:parent/companies';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"company":{"careerSiteUri":"","derivedInfo":{"headquartersLocation":{"latLng":{"latitude":"","longitude":""},"locationType":"","postalAddress":{"addressLines":[],"administrativeArea":"","languageCode":"","locality":"","organization":"","postalCode":"","recipients":[],"regionCode":"","revision":0,"sortingCode":"","sublocality":""},"radiusInMiles":""}},"displayName":"","eeoText":"","externalId":"","headquartersAddress":"","hiringAgency":false,"imageUri":"","keywordSearchableJobCustomAttributes":[],"name":"","size":"","suspended":false,"websiteUri":""}}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"company": @{ @"careerSiteUri": @"", @"derivedInfo": @{ @"headquartersLocation": @{ @"latLng": @{ @"latitude": @"", @"longitude": @"" }, @"locationType": @"", @"postalAddress": @{ @"addressLines": @[  ], @"administrativeArea": @"", @"languageCode": @"", @"locality": @"", @"organization": @"", @"postalCode": @"", @"recipients": @[  ], @"regionCode": @"", @"revision": @0, @"sortingCode": @"", @"sublocality": @"" }, @"radiusInMiles": @"" } }, @"displayName": @"", @"eeoText": @"", @"externalId": @"", @"headquartersAddress": @"", @"hiringAgency": @NO, @"imageUri": @"", @"keywordSearchableJobCustomAttributes": @[  ], @"name": @"", @"size": @"", @"suspended": @NO, @"websiteUri": @"" } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3p1beta1/:parent/companies"]
                                                       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}}/v3p1beta1/:parent/companies" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3p1beta1/:parent/companies",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'company' => [
        'careerSiteUri' => '',
        'derivedInfo' => [
                'headquartersLocation' => [
                                'latLng' => [
                                                                'latitude' => '',
                                                                'longitude' => ''
                                ],
                                'locationType' => '',
                                'postalAddress' => [
                                                                'addressLines' => [
                                                                                                                                
                                                                ],
                                                                'administrativeArea' => '',
                                                                'languageCode' => '',
                                                                'locality' => '',
                                                                'organization' => '',
                                                                'postalCode' => '',
                                                                'recipients' => [
                                                                                                                                
                                                                ],
                                                                'regionCode' => '',
                                                                'revision' => 0,
                                                                'sortingCode' => '',
                                                                'sublocality' => ''
                                ],
                                'radiusInMiles' => ''
                ]
        ],
        'displayName' => '',
        'eeoText' => '',
        'externalId' => '',
        'headquartersAddress' => '',
        'hiringAgency' => null,
        'imageUri' => '',
        'keywordSearchableJobCustomAttributes' => [
                
        ],
        'name' => '',
        'size' => '',
        'suspended' => null,
        'websiteUri' => ''
    ]
  ]),
  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}}/v3p1beta1/:parent/companies', [
  'body' => '{
  "company": {
    "careerSiteUri": "",
    "derivedInfo": {
      "headquartersLocation": {
        "latLng": {
          "latitude": "",
          "longitude": ""
        },
        "locationType": "",
        "postalAddress": {
          "addressLines": [],
          "administrativeArea": "",
          "languageCode": "",
          "locality": "",
          "organization": "",
          "postalCode": "",
          "recipients": [],
          "regionCode": "",
          "revision": 0,
          "sortingCode": "",
          "sublocality": ""
        },
        "radiusInMiles": ""
      }
    },
    "displayName": "",
    "eeoText": "",
    "externalId": "",
    "headquartersAddress": "",
    "hiringAgency": false,
    "imageUri": "",
    "keywordSearchableJobCustomAttributes": [],
    "name": "",
    "size": "",
    "suspended": false,
    "websiteUri": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3p1beta1/:parent/companies');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'company' => [
    'careerSiteUri' => '',
    'derivedInfo' => [
        'headquartersLocation' => [
                'latLng' => [
                                'latitude' => '',
                                'longitude' => ''
                ],
                'locationType' => '',
                'postalAddress' => [
                                'addressLines' => [
                                                                
                                ],
                                'administrativeArea' => '',
                                'languageCode' => '',
                                'locality' => '',
                                'organization' => '',
                                'postalCode' => '',
                                'recipients' => [
                                                                
                                ],
                                'regionCode' => '',
                                'revision' => 0,
                                'sortingCode' => '',
                                'sublocality' => ''
                ],
                'radiusInMiles' => ''
        ]
    ],
    'displayName' => '',
    'eeoText' => '',
    'externalId' => '',
    'headquartersAddress' => '',
    'hiringAgency' => null,
    'imageUri' => '',
    'keywordSearchableJobCustomAttributes' => [
        
    ],
    'name' => '',
    'size' => '',
    'suspended' => null,
    'websiteUri' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'company' => [
    'careerSiteUri' => '',
    'derivedInfo' => [
        'headquartersLocation' => [
                'latLng' => [
                                'latitude' => '',
                                'longitude' => ''
                ],
                'locationType' => '',
                'postalAddress' => [
                                'addressLines' => [
                                                                
                                ],
                                'administrativeArea' => '',
                                'languageCode' => '',
                                'locality' => '',
                                'organization' => '',
                                'postalCode' => '',
                                'recipients' => [
                                                                
                                ],
                                'regionCode' => '',
                                'revision' => 0,
                                'sortingCode' => '',
                                'sublocality' => ''
                ],
                'radiusInMiles' => ''
        ]
    ],
    'displayName' => '',
    'eeoText' => '',
    'externalId' => '',
    'headquartersAddress' => '',
    'hiringAgency' => null,
    'imageUri' => '',
    'keywordSearchableJobCustomAttributes' => [
        
    ],
    'name' => '',
    'size' => '',
    'suspended' => null,
    'websiteUri' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3p1beta1/:parent/companies');
$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}}/v3p1beta1/:parent/companies' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "company": {
    "careerSiteUri": "",
    "derivedInfo": {
      "headquartersLocation": {
        "latLng": {
          "latitude": "",
          "longitude": ""
        },
        "locationType": "",
        "postalAddress": {
          "addressLines": [],
          "administrativeArea": "",
          "languageCode": "",
          "locality": "",
          "organization": "",
          "postalCode": "",
          "recipients": [],
          "regionCode": "",
          "revision": 0,
          "sortingCode": "",
          "sublocality": ""
        },
        "radiusInMiles": ""
      }
    },
    "displayName": "",
    "eeoText": "",
    "externalId": "",
    "headquartersAddress": "",
    "hiringAgency": false,
    "imageUri": "",
    "keywordSearchableJobCustomAttributes": [],
    "name": "",
    "size": "",
    "suspended": false,
    "websiteUri": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3p1beta1/:parent/companies' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "company": {
    "careerSiteUri": "",
    "derivedInfo": {
      "headquartersLocation": {
        "latLng": {
          "latitude": "",
          "longitude": ""
        },
        "locationType": "",
        "postalAddress": {
          "addressLines": [],
          "administrativeArea": "",
          "languageCode": "",
          "locality": "",
          "organization": "",
          "postalCode": "",
          "recipients": [],
          "regionCode": "",
          "revision": 0,
          "sortingCode": "",
          "sublocality": ""
        },
        "radiusInMiles": ""
      }
    },
    "displayName": "",
    "eeoText": "",
    "externalId": "",
    "headquartersAddress": "",
    "hiringAgency": false,
    "imageUri": "",
    "keywordSearchableJobCustomAttributes": [],
    "name": "",
    "size": "",
    "suspended": false,
    "websiteUri": ""
  }
}'
import http.client

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

payload = "{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\n  }\n}"

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

conn.request("POST", "/baseUrl/v3p1beta1/:parent/companies", payload, headers)

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

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

url = "{{baseUrl}}/v3p1beta1/:parent/companies"

payload = { "company": {
        "careerSiteUri": "",
        "derivedInfo": { "headquartersLocation": {
                "latLng": {
                    "latitude": "",
                    "longitude": ""
                },
                "locationType": "",
                "postalAddress": {
                    "addressLines": [],
                    "administrativeArea": "",
                    "languageCode": "",
                    "locality": "",
                    "organization": "",
                    "postalCode": "",
                    "recipients": [],
                    "regionCode": "",
                    "revision": 0,
                    "sortingCode": "",
                    "sublocality": ""
                },
                "radiusInMiles": ""
            } },
        "displayName": "",
        "eeoText": "",
        "externalId": "",
        "headquartersAddress": "",
        "hiringAgency": False,
        "imageUri": "",
        "keywordSearchableJobCustomAttributes": [],
        "name": "",
        "size": "",
        "suspended": False,
        "websiteUri": ""
    } }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3p1beta1/:parent/companies"

payload <- "{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\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}}/v3p1beta1/:parent/companies")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\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/v3p1beta1/:parent/companies') do |req|
  req.body = "{\n  \"company\": {\n    \"careerSiteUri\": \"\",\n    \"derivedInfo\": {\n      \"headquartersLocation\": {\n        \"latLng\": {\n          \"latitude\": \"\",\n          \"longitude\": \"\"\n        },\n        \"locationType\": \"\",\n        \"postalAddress\": {\n          \"addressLines\": [],\n          \"administrativeArea\": \"\",\n          \"languageCode\": \"\",\n          \"locality\": \"\",\n          \"organization\": \"\",\n          \"postalCode\": \"\",\n          \"recipients\": [],\n          \"regionCode\": \"\",\n          \"revision\": 0,\n          \"sortingCode\": \"\",\n          \"sublocality\": \"\"\n        },\n        \"radiusInMiles\": \"\"\n      }\n    },\n    \"displayName\": \"\",\n    \"eeoText\": \"\",\n    \"externalId\": \"\",\n    \"headquartersAddress\": \"\",\n    \"hiringAgency\": false,\n    \"imageUri\": \"\",\n    \"keywordSearchableJobCustomAttributes\": [],\n    \"name\": \"\",\n    \"size\": \"\",\n    \"suspended\": false,\n    \"websiteUri\": \"\"\n  }\n}"
end

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

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

    let payload = json!({"company": json!({
            "careerSiteUri": "",
            "derivedInfo": json!({"headquartersLocation": json!({
                    "latLng": json!({
                        "latitude": "",
                        "longitude": ""
                    }),
                    "locationType": "",
                    "postalAddress": json!({
                        "addressLines": (),
                        "administrativeArea": "",
                        "languageCode": "",
                        "locality": "",
                        "organization": "",
                        "postalCode": "",
                        "recipients": (),
                        "regionCode": "",
                        "revision": 0,
                        "sortingCode": "",
                        "sublocality": ""
                    }),
                    "radiusInMiles": ""
                })}),
            "displayName": "",
            "eeoText": "",
            "externalId": "",
            "headquartersAddress": "",
            "hiringAgency": false,
            "imageUri": "",
            "keywordSearchableJobCustomAttributes": (),
            "name": "",
            "size": "",
            "suspended": false,
            "websiteUri": ""
        })});

    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}}/v3p1beta1/:parent/companies \
  --header 'content-type: application/json' \
  --data '{
  "company": {
    "careerSiteUri": "",
    "derivedInfo": {
      "headquartersLocation": {
        "latLng": {
          "latitude": "",
          "longitude": ""
        },
        "locationType": "",
        "postalAddress": {
          "addressLines": [],
          "administrativeArea": "",
          "languageCode": "",
          "locality": "",
          "organization": "",
          "postalCode": "",
          "recipients": [],
          "regionCode": "",
          "revision": 0,
          "sortingCode": "",
          "sublocality": ""
        },
        "radiusInMiles": ""
      }
    },
    "displayName": "",
    "eeoText": "",
    "externalId": "",
    "headquartersAddress": "",
    "hiringAgency": false,
    "imageUri": "",
    "keywordSearchableJobCustomAttributes": [],
    "name": "",
    "size": "",
    "suspended": false,
    "websiteUri": ""
  }
}'
echo '{
  "company": {
    "careerSiteUri": "",
    "derivedInfo": {
      "headquartersLocation": {
        "latLng": {
          "latitude": "",
          "longitude": ""
        },
        "locationType": "",
        "postalAddress": {
          "addressLines": [],
          "administrativeArea": "",
          "languageCode": "",
          "locality": "",
          "organization": "",
          "postalCode": "",
          "recipients": [],
          "regionCode": "",
          "revision": 0,
          "sortingCode": "",
          "sublocality": ""
        },
        "radiusInMiles": ""
      }
    },
    "displayName": "",
    "eeoText": "",
    "externalId": "",
    "headquartersAddress": "",
    "hiringAgency": false,
    "imageUri": "",
    "keywordSearchableJobCustomAttributes": [],
    "name": "",
    "size": "",
    "suspended": false,
    "websiteUri": ""
  }
}' |  \
  http POST {{baseUrl}}/v3p1beta1/:parent/companies \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "company": {\n    "careerSiteUri": "",\n    "derivedInfo": {\n      "headquartersLocation": {\n        "latLng": {\n          "latitude": "",\n          "longitude": ""\n        },\n        "locationType": "",\n        "postalAddress": {\n          "addressLines": [],\n          "administrativeArea": "",\n          "languageCode": "",\n          "locality": "",\n          "organization": "",\n          "postalCode": "",\n          "recipients": [],\n          "regionCode": "",\n          "revision": 0,\n          "sortingCode": "",\n          "sublocality": ""\n        },\n        "radiusInMiles": ""\n      }\n    },\n    "displayName": "",\n    "eeoText": "",\n    "externalId": "",\n    "headquartersAddress": "",\n    "hiringAgency": false,\n    "imageUri": "",\n    "keywordSearchableJobCustomAttributes": [],\n    "name": "",\n    "size": "",\n    "suspended": false,\n    "websiteUri": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:parent/companies
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["company": [
    "careerSiteUri": "",
    "derivedInfo": ["headquartersLocation": [
        "latLng": [
          "latitude": "",
          "longitude": ""
        ],
        "locationType": "",
        "postalAddress": [
          "addressLines": [],
          "administrativeArea": "",
          "languageCode": "",
          "locality": "",
          "organization": "",
          "postalCode": "",
          "recipients": [],
          "regionCode": "",
          "revision": 0,
          "sortingCode": "",
          "sublocality": ""
        ],
        "radiusInMiles": ""
      ]],
    "displayName": "",
    "eeoText": "",
    "externalId": "",
    "headquartersAddress": "",
    "hiringAgency": false,
    "imageUri": "",
    "keywordSearchableJobCustomAttributes": [],
    "name": "",
    "size": "",
    "suspended": false,
    "websiteUri": ""
  ]] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3p1beta1/:parent/companies")! 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 jobs.projects.companies.list
{{baseUrl}}/v3p1beta1/:parent/companies
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3p1beta1/:parent/companies");

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

(client/get "{{baseUrl}}/v3p1beta1/:parent/companies")
require "http/client"

url = "{{baseUrl}}/v3p1beta1/:parent/companies"

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

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/:parent/companies"

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

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

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

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

}
GET /baseUrl/v3p1beta1/:parent/companies HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/companies")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v3p1beta1/:parent/companies")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v3p1beta1/:parent/companies');

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

const options = {method: 'GET', url: '{{baseUrl}}/v3p1beta1/:parent/companies'};

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

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/companies")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3p1beta1/:parent/companies',
  headers: {}
};

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v3p1beta1/:parent/companies'};

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

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

const req = unirest('GET', '{{baseUrl}}/v3p1beta1/:parent/companies');

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v3p1beta1/:parent/companies'};

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

const url = '{{baseUrl}}/v3p1beta1/:parent/companies';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3p1beta1/:parent/companies"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/v3p1beta1/:parent/companies" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v3p1beta1/:parent/companies');

echo $response->getBody();
setUrl('{{baseUrl}}/v3p1beta1/:parent/companies');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3p1beta1/:parent/companies');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3p1beta1/:parent/companies' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3p1beta1/:parent/companies' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v3p1beta1/:parent/companies")

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

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

url = "{{baseUrl}}/v3p1beta1/:parent/companies"

response = requests.get(url)

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

url <- "{{baseUrl}}/v3p1beta1/:parent/companies"

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

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

url = URI("{{baseUrl}}/v3p1beta1/:parent/companies")

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

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

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

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

response = conn.get('/baseUrl/v3p1beta1/:parent/companies') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v3p1beta1/:parent/companies
http GET {{baseUrl}}/v3p1beta1/:parent/companies
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:parent/companies
import Foundation

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

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

dataTask.resume()
GET jobs.projects.complete
{{baseUrl}}/v3p1beta1/:name:complete
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3p1beta1/:name:complete");

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

(client/get "{{baseUrl}}/v3p1beta1/:name:complete")
require "http/client"

url = "{{baseUrl}}/v3p1beta1/:name:complete"

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

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/:name:complete"

	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/v3p1beta1/:name:complete HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:name:complete")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v3p1beta1/:name:complete")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v3p1beta1/:name:complete');

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

const options = {method: 'GET', url: '{{baseUrl}}/v3p1beta1/:name:complete'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:name:complete")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3p1beta1/:name:complete',
  headers: {}
};

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v3p1beta1/:name:complete'};

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

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

const req = unirest('GET', '{{baseUrl}}/v3p1beta1/:name:complete');

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v3p1beta1/:name:complete'};

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

const url = '{{baseUrl}}/v3p1beta1/:name:complete';
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}}/v3p1beta1/:name:complete"]
                                                       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}}/v3p1beta1/:name:complete" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v3p1beta1/:name:complete');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3p1beta1/:name:complete');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3p1beta1/:name:complete' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3p1beta1/:name:complete' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v3p1beta1/:name:complete")

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

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

url = "{{baseUrl}}/v3p1beta1/:name:complete"

response = requests.get(url)

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

url <- "{{baseUrl}}/v3p1beta1/:name:complete"

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

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

url = URI("{{baseUrl}}/v3p1beta1/:name:complete")

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/v3p1beta1/:name:complete') do |req|
end

puts response.status
puts response.body
use reqwest;

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

    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}}/v3p1beta1/:name:complete
http GET {{baseUrl}}/v3p1beta1/:name:complete
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:name:complete
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3p1beta1/:name:complete")! 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 jobs.projects.jobs.batchDelete
{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete
QUERY PARAMS

parent
BODY json

{
  "filter": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete");

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

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

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

(client/post "{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete" {:content-type :json
                                                                               :form-params {:filter ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete"

	payload := strings.NewReader("{\n  \"filter\": \"\"\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/v3p1beta1/:parent/jobs:batchDelete HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 18

{
  "filter": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"filter\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"filter\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete")
  .header("content-type", "application/json")
  .body("{\n  \"filter\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  filter: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete',
  headers: {'content-type': 'application/json'},
  data: {filter: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filter":""}'
};

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

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"filter\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete")
  .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/v3p1beta1/:parent/jobs:batchDelete',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete',
  headers: {'content-type': 'application/json'},
  body: {filter: ''},
  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}}/v3p1beta1/:parent/jobs:batchDelete');

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete',
  headers: {'content-type': 'application/json'},
  data: {filter: ''}
};

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

const url = '{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"filter":""}'
};

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

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

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

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

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

echo $response->getBody();
setUrl('{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete');
$request->setMethod(HTTP_METH_POST);

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

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

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

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

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

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

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

conn.request("POST", "/baseUrl/v3p1beta1/:parent/jobs:batchDelete", payload, headers)

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

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

url = "{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete"

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

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

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

url <- "{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete"

payload <- "{\n  \"filter\": \"\"\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}}/v3p1beta1/:parent/jobs:batchDelete")

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

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

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/v3p1beta1/:parent/jobs:batchDelete') do |req|
  req.body = "{\n  \"filter\": \"\"\n}"
end

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

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

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

    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}}/v3p1beta1/:parent/jobs:batchDelete \
  --header 'content-type: application/json' \
  --data '{
  "filter": ""
}'
echo '{
  "filter": ""
}' |  \
  http POST {{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "filter": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete
import Foundation

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3p1beta1/:parent/jobs:batchDelete")! 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 jobs.projects.jobs.create
{{baseUrl}}/v3p1beta1/:parent/jobs
QUERY PARAMS

parent
BODY json

{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3p1beta1/:parent/jobs");

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  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  }\n}");

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

(client/post "{{baseUrl}}/v3p1beta1/:parent/jobs" {:content-type :json
                                                                   :form-params {:job {:addresses []
                                                                                       :applicationInfo {:emails []
                                                                                                         :instruction ""
                                                                                                         :uris []}
                                                                                       :companyDisplayName ""
                                                                                       :companyName ""
                                                                                       :compensationInfo {:annualizedBaseCompensationRange {:maxCompensation {:currencyCode ""
                                                                                                                                                              :nanos 0
                                                                                                                                                              :units ""}
                                                                                                                                            :minCompensation {}}
                                                                                                          :annualizedTotalCompensationRange {}
                                                                                                          :entries [{:amount {}
                                                                                                                     :description ""
                                                                                                                     :expectedUnitsPerYear ""
                                                                                                                     :range {}
                                                                                                                     :type ""
                                                                                                                     :unit ""}]}
                                                                                       :customAttributes {}
                                                                                       :degreeTypes []
                                                                                       :department ""
                                                                                       :derivedInfo {:jobCategories []
                                                                                                     :locations [{:latLng {:latitude ""
                                                                                                                           :longitude ""}
                                                                                                                  :locationType ""
                                                                                                                  :postalAddress {:addressLines []
                                                                                                                                  :administrativeArea ""
                                                                                                                                  :languageCode ""
                                                                                                                                  :locality ""
                                                                                                                                  :organization ""
                                                                                                                                  :postalCode ""
                                                                                                                                  :recipients []
                                                                                                                                  :regionCode ""
                                                                                                                                  :revision 0
                                                                                                                                  :sortingCode ""
                                                                                                                                  :sublocality ""}
                                                                                                                  :radiusInMiles ""}]}
                                                                                       :description ""
                                                                                       :employmentTypes []
                                                                                       :incentives ""
                                                                                       :jobBenefits []
                                                                                       :jobEndTime ""
                                                                                       :jobLevel ""
                                                                                       :jobStartTime ""
                                                                                       :languageCode ""
                                                                                       :name ""
                                                                                       :postingCreateTime ""
                                                                                       :postingExpireTime ""
                                                                                       :postingPublishTime ""
                                                                                       :postingRegion ""
                                                                                       :postingUpdateTime ""
                                                                                       :processingOptions {:disableStreetAddressResolution false
                                                                                                           :htmlSanitization ""}
                                                                                       :promotionValue 0
                                                                                       :qualifications ""
                                                                                       :requisitionId ""
                                                                                       :responsibilities ""
                                                                                       :title ""
                                                                                       :visibility ""}}})
require "http/client"

url = "{{baseUrl}}/v3p1beta1/:parent/jobs"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\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}}/v3p1beta1/:parent/jobs"),
    Content = new StringContent("{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\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}}/v3p1beta1/:parent/jobs");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/:parent/jobs"

	payload := strings.NewReader("{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\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/v3p1beta1/:parent/jobs HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1970

{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3p1beta1/:parent/jobs")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3p1beta1/:parent/jobs"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\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  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/jobs")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3p1beta1/:parent/jobs")
  .header("content-type", "application/json")
  .body("{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  job: {
    addresses: [],
    applicationInfo: {
      emails: [],
      instruction: '',
      uris: []
    },
    companyDisplayName: '',
    companyName: '',
    compensationInfo: {
      annualizedBaseCompensationRange: {
        maxCompensation: {
          currencyCode: '',
          nanos: 0,
          units: ''
        },
        minCompensation: {}
      },
      annualizedTotalCompensationRange: {},
      entries: [
        {
          amount: {},
          description: '',
          expectedUnitsPerYear: '',
          range: {},
          type: '',
          unit: ''
        }
      ]
    },
    customAttributes: {},
    degreeTypes: [],
    department: '',
    derivedInfo: {
      jobCategories: [],
      locations: [
        {
          latLng: {
            latitude: '',
            longitude: ''
          },
          locationType: '',
          postalAddress: {
            addressLines: [],
            administrativeArea: '',
            languageCode: '',
            locality: '',
            organization: '',
            postalCode: '',
            recipients: [],
            regionCode: '',
            revision: 0,
            sortingCode: '',
            sublocality: ''
          },
          radiusInMiles: ''
        }
      ]
    },
    description: '',
    employmentTypes: [],
    incentives: '',
    jobBenefits: [],
    jobEndTime: '',
    jobLevel: '',
    jobStartTime: '',
    languageCode: '',
    name: '',
    postingCreateTime: '',
    postingExpireTime: '',
    postingPublishTime: '',
    postingRegion: '',
    postingUpdateTime: '',
    processingOptions: {
      disableStreetAddressResolution: false,
      htmlSanitization: ''
    },
    promotionValue: 0,
    qualifications: '',
    requisitionId: '',
    responsibilities: '',
    title: '',
    visibility: ''
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/v3p1beta1/:parent/jobs');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs',
  headers: {'content-type': 'application/json'},
  data: {
    job: {
      addresses: [],
      applicationInfo: {emails: [], instruction: '', uris: []},
      companyDisplayName: '',
      companyName: '',
      compensationInfo: {
        annualizedBaseCompensationRange: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        annualizedTotalCompensationRange: {},
        entries: [
          {
            amount: {},
            description: '',
            expectedUnitsPerYear: '',
            range: {},
            type: '',
            unit: ''
          }
        ]
      },
      customAttributes: {},
      degreeTypes: [],
      department: '',
      derivedInfo: {
        jobCategories: [],
        locations: [
          {
            latLng: {latitude: '', longitude: ''},
            locationType: '',
            postalAddress: {
              addressLines: [],
              administrativeArea: '',
              languageCode: '',
              locality: '',
              organization: '',
              postalCode: '',
              recipients: [],
              regionCode: '',
              revision: 0,
              sortingCode: '',
              sublocality: ''
            },
            radiusInMiles: ''
          }
        ]
      },
      description: '',
      employmentTypes: [],
      incentives: '',
      jobBenefits: [],
      jobEndTime: '',
      jobLevel: '',
      jobStartTime: '',
      languageCode: '',
      name: '',
      postingCreateTime: '',
      postingExpireTime: '',
      postingPublishTime: '',
      postingRegion: '',
      postingUpdateTime: '',
      processingOptions: {disableStreetAddressResolution: false, htmlSanitization: ''},
      promotionValue: 0,
      qualifications: '',
      requisitionId: '',
      responsibilities: '',
      title: '',
      visibility: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3p1beta1/:parent/jobs';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"job":{"addresses":[],"applicationInfo":{"emails":[],"instruction":"","uris":[]},"companyDisplayName":"","companyName":"","compensationInfo":{"annualizedBaseCompensationRange":{"maxCompensation":{"currencyCode":"","nanos":0,"units":""},"minCompensation":{}},"annualizedTotalCompensationRange":{},"entries":[{"amount":{},"description":"","expectedUnitsPerYear":"","range":{},"type":"","unit":""}]},"customAttributes":{},"degreeTypes":[],"department":"","derivedInfo":{"jobCategories":[],"locations":[{"latLng":{"latitude":"","longitude":""},"locationType":"","postalAddress":{"addressLines":[],"administrativeArea":"","languageCode":"","locality":"","organization":"","postalCode":"","recipients":[],"regionCode":"","revision":0,"sortingCode":"","sublocality":""},"radiusInMiles":""}]},"description":"","employmentTypes":[],"incentives":"","jobBenefits":[],"jobEndTime":"","jobLevel":"","jobStartTime":"","languageCode":"","name":"","postingCreateTime":"","postingExpireTime":"","postingPublishTime":"","postingRegion":"","postingUpdateTime":"","processingOptions":{"disableStreetAddressResolution":false,"htmlSanitization":""},"promotionValue":0,"qualifications":"","requisitionId":"","responsibilities":"","title":"","visibility":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "job": {\n    "addresses": [],\n    "applicationInfo": {\n      "emails": [],\n      "instruction": "",\n      "uris": []\n    },\n    "companyDisplayName": "",\n    "companyName": "",\n    "compensationInfo": {\n      "annualizedBaseCompensationRange": {\n        "maxCompensation": {\n          "currencyCode": "",\n          "nanos": 0,\n          "units": ""\n        },\n        "minCompensation": {}\n      },\n      "annualizedTotalCompensationRange": {},\n      "entries": [\n        {\n          "amount": {},\n          "description": "",\n          "expectedUnitsPerYear": "",\n          "range": {},\n          "type": "",\n          "unit": ""\n        }\n      ]\n    },\n    "customAttributes": {},\n    "degreeTypes": [],\n    "department": "",\n    "derivedInfo": {\n      "jobCategories": [],\n      "locations": [\n        {\n          "latLng": {\n            "latitude": "",\n            "longitude": ""\n          },\n          "locationType": "",\n          "postalAddress": {\n            "addressLines": [],\n            "administrativeArea": "",\n            "languageCode": "",\n            "locality": "",\n            "organization": "",\n            "postalCode": "",\n            "recipients": [],\n            "regionCode": "",\n            "revision": 0,\n            "sortingCode": "",\n            "sublocality": ""\n          },\n          "radiusInMiles": ""\n        }\n      ]\n    },\n    "description": "",\n    "employmentTypes": [],\n    "incentives": "",\n    "jobBenefits": [],\n    "jobEndTime": "",\n    "jobLevel": "",\n    "jobStartTime": "",\n    "languageCode": "",\n    "name": "",\n    "postingCreateTime": "",\n    "postingExpireTime": "",\n    "postingPublishTime": "",\n    "postingRegion": "",\n    "postingUpdateTime": "",\n    "processingOptions": {\n      "disableStreetAddressResolution": false,\n      "htmlSanitization": ""\n    },\n    "promotionValue": 0,\n    "qualifications": "",\n    "requisitionId": "",\n    "responsibilities": "",\n    "title": "",\n    "visibility": ""\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  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/jobs")
  .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/v3p1beta1/:parent/jobs',
  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({
  job: {
    addresses: [],
    applicationInfo: {emails: [], instruction: '', uris: []},
    companyDisplayName: '',
    companyName: '',
    compensationInfo: {
      annualizedBaseCompensationRange: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
      annualizedTotalCompensationRange: {},
      entries: [
        {
          amount: {},
          description: '',
          expectedUnitsPerYear: '',
          range: {},
          type: '',
          unit: ''
        }
      ]
    },
    customAttributes: {},
    degreeTypes: [],
    department: '',
    derivedInfo: {
      jobCategories: [],
      locations: [
        {
          latLng: {latitude: '', longitude: ''},
          locationType: '',
          postalAddress: {
            addressLines: [],
            administrativeArea: '',
            languageCode: '',
            locality: '',
            organization: '',
            postalCode: '',
            recipients: [],
            regionCode: '',
            revision: 0,
            sortingCode: '',
            sublocality: ''
          },
          radiusInMiles: ''
        }
      ]
    },
    description: '',
    employmentTypes: [],
    incentives: '',
    jobBenefits: [],
    jobEndTime: '',
    jobLevel: '',
    jobStartTime: '',
    languageCode: '',
    name: '',
    postingCreateTime: '',
    postingExpireTime: '',
    postingPublishTime: '',
    postingRegion: '',
    postingUpdateTime: '',
    processingOptions: {disableStreetAddressResolution: false, htmlSanitization: ''},
    promotionValue: 0,
    qualifications: '',
    requisitionId: '',
    responsibilities: '',
    title: '',
    visibility: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs',
  headers: {'content-type': 'application/json'},
  body: {
    job: {
      addresses: [],
      applicationInfo: {emails: [], instruction: '', uris: []},
      companyDisplayName: '',
      companyName: '',
      compensationInfo: {
        annualizedBaseCompensationRange: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        annualizedTotalCompensationRange: {},
        entries: [
          {
            amount: {},
            description: '',
            expectedUnitsPerYear: '',
            range: {},
            type: '',
            unit: ''
          }
        ]
      },
      customAttributes: {},
      degreeTypes: [],
      department: '',
      derivedInfo: {
        jobCategories: [],
        locations: [
          {
            latLng: {latitude: '', longitude: ''},
            locationType: '',
            postalAddress: {
              addressLines: [],
              administrativeArea: '',
              languageCode: '',
              locality: '',
              organization: '',
              postalCode: '',
              recipients: [],
              regionCode: '',
              revision: 0,
              sortingCode: '',
              sublocality: ''
            },
            radiusInMiles: ''
          }
        ]
      },
      description: '',
      employmentTypes: [],
      incentives: '',
      jobBenefits: [],
      jobEndTime: '',
      jobLevel: '',
      jobStartTime: '',
      languageCode: '',
      name: '',
      postingCreateTime: '',
      postingExpireTime: '',
      postingPublishTime: '',
      postingRegion: '',
      postingUpdateTime: '',
      processingOptions: {disableStreetAddressResolution: false, htmlSanitization: ''},
      promotionValue: 0,
      qualifications: '',
      requisitionId: '',
      responsibilities: '',
      title: '',
      visibility: ''
    }
  },
  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}}/v3p1beta1/:parent/jobs');

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

req.type('json');
req.send({
  job: {
    addresses: [],
    applicationInfo: {
      emails: [],
      instruction: '',
      uris: []
    },
    companyDisplayName: '',
    companyName: '',
    compensationInfo: {
      annualizedBaseCompensationRange: {
        maxCompensation: {
          currencyCode: '',
          nanos: 0,
          units: ''
        },
        minCompensation: {}
      },
      annualizedTotalCompensationRange: {},
      entries: [
        {
          amount: {},
          description: '',
          expectedUnitsPerYear: '',
          range: {},
          type: '',
          unit: ''
        }
      ]
    },
    customAttributes: {},
    degreeTypes: [],
    department: '',
    derivedInfo: {
      jobCategories: [],
      locations: [
        {
          latLng: {
            latitude: '',
            longitude: ''
          },
          locationType: '',
          postalAddress: {
            addressLines: [],
            administrativeArea: '',
            languageCode: '',
            locality: '',
            organization: '',
            postalCode: '',
            recipients: [],
            regionCode: '',
            revision: 0,
            sortingCode: '',
            sublocality: ''
          },
          radiusInMiles: ''
        }
      ]
    },
    description: '',
    employmentTypes: [],
    incentives: '',
    jobBenefits: [],
    jobEndTime: '',
    jobLevel: '',
    jobStartTime: '',
    languageCode: '',
    name: '',
    postingCreateTime: '',
    postingExpireTime: '',
    postingPublishTime: '',
    postingRegion: '',
    postingUpdateTime: '',
    processingOptions: {
      disableStreetAddressResolution: false,
      htmlSanitization: ''
    },
    promotionValue: 0,
    qualifications: '',
    requisitionId: '',
    responsibilities: '',
    title: '',
    visibility: ''
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs',
  headers: {'content-type': 'application/json'},
  data: {
    job: {
      addresses: [],
      applicationInfo: {emails: [], instruction: '', uris: []},
      companyDisplayName: '',
      companyName: '',
      compensationInfo: {
        annualizedBaseCompensationRange: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        annualizedTotalCompensationRange: {},
        entries: [
          {
            amount: {},
            description: '',
            expectedUnitsPerYear: '',
            range: {},
            type: '',
            unit: ''
          }
        ]
      },
      customAttributes: {},
      degreeTypes: [],
      department: '',
      derivedInfo: {
        jobCategories: [],
        locations: [
          {
            latLng: {latitude: '', longitude: ''},
            locationType: '',
            postalAddress: {
              addressLines: [],
              administrativeArea: '',
              languageCode: '',
              locality: '',
              organization: '',
              postalCode: '',
              recipients: [],
              regionCode: '',
              revision: 0,
              sortingCode: '',
              sublocality: ''
            },
            radiusInMiles: ''
          }
        ]
      },
      description: '',
      employmentTypes: [],
      incentives: '',
      jobBenefits: [],
      jobEndTime: '',
      jobLevel: '',
      jobStartTime: '',
      languageCode: '',
      name: '',
      postingCreateTime: '',
      postingExpireTime: '',
      postingPublishTime: '',
      postingRegion: '',
      postingUpdateTime: '',
      processingOptions: {disableStreetAddressResolution: false, htmlSanitization: ''},
      promotionValue: 0,
      qualifications: '',
      requisitionId: '',
      responsibilities: '',
      title: '',
      visibility: ''
    }
  }
};

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

const url = '{{baseUrl}}/v3p1beta1/:parent/jobs';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"job":{"addresses":[],"applicationInfo":{"emails":[],"instruction":"","uris":[]},"companyDisplayName":"","companyName":"","compensationInfo":{"annualizedBaseCompensationRange":{"maxCompensation":{"currencyCode":"","nanos":0,"units":""},"minCompensation":{}},"annualizedTotalCompensationRange":{},"entries":[{"amount":{},"description":"","expectedUnitsPerYear":"","range":{},"type":"","unit":""}]},"customAttributes":{},"degreeTypes":[],"department":"","derivedInfo":{"jobCategories":[],"locations":[{"latLng":{"latitude":"","longitude":""},"locationType":"","postalAddress":{"addressLines":[],"administrativeArea":"","languageCode":"","locality":"","organization":"","postalCode":"","recipients":[],"regionCode":"","revision":0,"sortingCode":"","sublocality":""},"radiusInMiles":""}]},"description":"","employmentTypes":[],"incentives":"","jobBenefits":[],"jobEndTime":"","jobLevel":"","jobStartTime":"","languageCode":"","name":"","postingCreateTime":"","postingExpireTime":"","postingPublishTime":"","postingRegion":"","postingUpdateTime":"","processingOptions":{"disableStreetAddressResolution":false,"htmlSanitization":""},"promotionValue":0,"qualifications":"","requisitionId":"","responsibilities":"","title":"","visibility":""}}'
};

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 = @{ @"job": @{ @"addresses": @[  ], @"applicationInfo": @{ @"emails": @[  ], @"instruction": @"", @"uris": @[  ] }, @"companyDisplayName": @"", @"companyName": @"", @"compensationInfo": @{ @"annualizedBaseCompensationRange": @{ @"maxCompensation": @{ @"currencyCode": @"", @"nanos": @0, @"units": @"" }, @"minCompensation": @{  } }, @"annualizedTotalCompensationRange": @{  }, @"entries": @[ @{ @"amount": @{  }, @"description": @"", @"expectedUnitsPerYear": @"", @"range": @{  }, @"type": @"", @"unit": @"" } ] }, @"customAttributes": @{  }, @"degreeTypes": @[  ], @"department": @"", @"derivedInfo": @{ @"jobCategories": @[  ], @"locations": @[ @{ @"latLng": @{ @"latitude": @"", @"longitude": @"" }, @"locationType": @"", @"postalAddress": @{ @"addressLines": @[  ], @"administrativeArea": @"", @"languageCode": @"", @"locality": @"", @"organization": @"", @"postalCode": @"", @"recipients": @[  ], @"regionCode": @"", @"revision": @0, @"sortingCode": @"", @"sublocality": @"" }, @"radiusInMiles": @"" } ] }, @"description": @"", @"employmentTypes": @[  ], @"incentives": @"", @"jobBenefits": @[  ], @"jobEndTime": @"", @"jobLevel": @"", @"jobStartTime": @"", @"languageCode": @"", @"name": @"", @"postingCreateTime": @"", @"postingExpireTime": @"", @"postingPublishTime": @"", @"postingRegion": @"", @"postingUpdateTime": @"", @"processingOptions": @{ @"disableStreetAddressResolution": @NO, @"htmlSanitization": @"" }, @"promotionValue": @0, @"qualifications": @"", @"requisitionId": @"", @"responsibilities": @"", @"title": @"", @"visibility": @"" } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3p1beta1/:parent/jobs"]
                                                       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}}/v3p1beta1/:parent/jobs" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3p1beta1/:parent/jobs",
  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([
    'job' => [
        'addresses' => [
                
        ],
        'applicationInfo' => [
                'emails' => [
                                
                ],
                'instruction' => '',
                'uris' => [
                                
                ]
        ],
        'companyDisplayName' => '',
        'companyName' => '',
        'compensationInfo' => [
                'annualizedBaseCompensationRange' => [
                                'maxCompensation' => [
                                                                'currencyCode' => '',
                                                                'nanos' => 0,
                                                                'units' => ''
                                ],
                                'minCompensation' => [
                                                                
                                ]
                ],
                'annualizedTotalCompensationRange' => [
                                
                ],
                'entries' => [
                                [
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'description' => '',
                                                                'expectedUnitsPerYear' => '',
                                                                'range' => [
                                                                                                                                
                                                                ],
                                                                'type' => '',
                                                                'unit' => ''
                                ]
                ]
        ],
        'customAttributes' => [
                
        ],
        'degreeTypes' => [
                
        ],
        'department' => '',
        'derivedInfo' => [
                'jobCategories' => [
                                
                ],
                'locations' => [
                                [
                                                                'latLng' => [
                                                                                                                                'latitude' => '',
                                                                                                                                'longitude' => ''
                                                                ],
                                                                'locationType' => '',
                                                                'postalAddress' => [
                                                                                                                                'addressLines' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'administrativeArea' => '',
                                                                                                                                'languageCode' => '',
                                                                                                                                'locality' => '',
                                                                                                                                'organization' => '',
                                                                                                                                'postalCode' => '',
                                                                                                                                'recipients' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'regionCode' => '',
                                                                                                                                'revision' => 0,
                                                                                                                                'sortingCode' => '',
                                                                                                                                'sublocality' => ''
                                                                ],
                                                                'radiusInMiles' => ''
                                ]
                ]
        ],
        'description' => '',
        'employmentTypes' => [
                
        ],
        'incentives' => '',
        'jobBenefits' => [
                
        ],
        'jobEndTime' => '',
        'jobLevel' => '',
        'jobStartTime' => '',
        'languageCode' => '',
        'name' => '',
        'postingCreateTime' => '',
        'postingExpireTime' => '',
        'postingPublishTime' => '',
        'postingRegion' => '',
        'postingUpdateTime' => '',
        'processingOptions' => [
                'disableStreetAddressResolution' => null,
                'htmlSanitization' => ''
        ],
        'promotionValue' => 0,
        'qualifications' => '',
        'requisitionId' => '',
        'responsibilities' => '',
        'title' => '',
        'visibility' => ''
    ]
  ]),
  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}}/v3p1beta1/:parent/jobs', [
  'body' => '{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3p1beta1/:parent/jobs');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'job' => [
    'addresses' => [
        
    ],
    'applicationInfo' => [
        'emails' => [
                
        ],
        'instruction' => '',
        'uris' => [
                
        ]
    ],
    'companyDisplayName' => '',
    'companyName' => '',
    'compensationInfo' => [
        'annualizedBaseCompensationRange' => [
                'maxCompensation' => [
                                'currencyCode' => '',
                                'nanos' => 0,
                                'units' => ''
                ],
                'minCompensation' => [
                                
                ]
        ],
        'annualizedTotalCompensationRange' => [
                
        ],
        'entries' => [
                [
                                'amount' => [
                                                                
                                ],
                                'description' => '',
                                'expectedUnitsPerYear' => '',
                                'range' => [
                                                                
                                ],
                                'type' => '',
                                'unit' => ''
                ]
        ]
    ],
    'customAttributes' => [
        
    ],
    'degreeTypes' => [
        
    ],
    'department' => '',
    'derivedInfo' => [
        'jobCategories' => [
                
        ],
        'locations' => [
                [
                                'latLng' => [
                                                                'latitude' => '',
                                                                'longitude' => ''
                                ],
                                'locationType' => '',
                                'postalAddress' => [
                                                                'addressLines' => [
                                                                                                                                
                                                                ],
                                                                'administrativeArea' => '',
                                                                'languageCode' => '',
                                                                'locality' => '',
                                                                'organization' => '',
                                                                'postalCode' => '',
                                                                'recipients' => [
                                                                                                                                
                                                                ],
                                                                'regionCode' => '',
                                                                'revision' => 0,
                                                                'sortingCode' => '',
                                                                'sublocality' => ''
                                ],
                                'radiusInMiles' => ''
                ]
        ]
    ],
    'description' => '',
    'employmentTypes' => [
        
    ],
    'incentives' => '',
    'jobBenefits' => [
        
    ],
    'jobEndTime' => '',
    'jobLevel' => '',
    'jobStartTime' => '',
    'languageCode' => '',
    'name' => '',
    'postingCreateTime' => '',
    'postingExpireTime' => '',
    'postingPublishTime' => '',
    'postingRegion' => '',
    'postingUpdateTime' => '',
    'processingOptions' => [
        'disableStreetAddressResolution' => null,
        'htmlSanitization' => ''
    ],
    'promotionValue' => 0,
    'qualifications' => '',
    'requisitionId' => '',
    'responsibilities' => '',
    'title' => '',
    'visibility' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'job' => [
    'addresses' => [
        
    ],
    'applicationInfo' => [
        'emails' => [
                
        ],
        'instruction' => '',
        'uris' => [
                
        ]
    ],
    'companyDisplayName' => '',
    'companyName' => '',
    'compensationInfo' => [
        'annualizedBaseCompensationRange' => [
                'maxCompensation' => [
                                'currencyCode' => '',
                                'nanos' => 0,
                                'units' => ''
                ],
                'minCompensation' => [
                                
                ]
        ],
        'annualizedTotalCompensationRange' => [
                
        ],
        'entries' => [
                [
                                'amount' => [
                                                                
                                ],
                                'description' => '',
                                'expectedUnitsPerYear' => '',
                                'range' => [
                                                                
                                ],
                                'type' => '',
                                'unit' => ''
                ]
        ]
    ],
    'customAttributes' => [
        
    ],
    'degreeTypes' => [
        
    ],
    'department' => '',
    'derivedInfo' => [
        'jobCategories' => [
                
        ],
        'locations' => [
                [
                                'latLng' => [
                                                                'latitude' => '',
                                                                'longitude' => ''
                                ],
                                'locationType' => '',
                                'postalAddress' => [
                                                                'addressLines' => [
                                                                                                                                
                                                                ],
                                                                'administrativeArea' => '',
                                                                'languageCode' => '',
                                                                'locality' => '',
                                                                'organization' => '',
                                                                'postalCode' => '',
                                                                'recipients' => [
                                                                                                                                
                                                                ],
                                                                'regionCode' => '',
                                                                'revision' => 0,
                                                                'sortingCode' => '',
                                                                'sublocality' => ''
                                ],
                                'radiusInMiles' => ''
                ]
        ]
    ],
    'description' => '',
    'employmentTypes' => [
        
    ],
    'incentives' => '',
    'jobBenefits' => [
        
    ],
    'jobEndTime' => '',
    'jobLevel' => '',
    'jobStartTime' => '',
    'languageCode' => '',
    'name' => '',
    'postingCreateTime' => '',
    'postingExpireTime' => '',
    'postingPublishTime' => '',
    'postingRegion' => '',
    'postingUpdateTime' => '',
    'processingOptions' => [
        'disableStreetAddressResolution' => null,
        'htmlSanitization' => ''
    ],
    'promotionValue' => 0,
    'qualifications' => '',
    'requisitionId' => '',
    'responsibilities' => '',
    'title' => '',
    'visibility' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v3p1beta1/:parent/jobs');
$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}}/v3p1beta1/:parent/jobs' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3p1beta1/:parent/jobs' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  }
}'
import http.client

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

payload = "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  }\n}"

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

conn.request("POST", "/baseUrl/v3p1beta1/:parent/jobs", payload, headers)

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

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

url = "{{baseUrl}}/v3p1beta1/:parent/jobs"

payload = { "job": {
        "addresses": [],
        "applicationInfo": {
            "emails": [],
            "instruction": "",
            "uris": []
        },
        "companyDisplayName": "",
        "companyName": "",
        "compensationInfo": {
            "annualizedBaseCompensationRange": {
                "maxCompensation": {
                    "currencyCode": "",
                    "nanos": 0,
                    "units": ""
                },
                "minCompensation": {}
            },
            "annualizedTotalCompensationRange": {},
            "entries": [
                {
                    "amount": {},
                    "description": "",
                    "expectedUnitsPerYear": "",
                    "range": {},
                    "type": "",
                    "unit": ""
                }
            ]
        },
        "customAttributes": {},
        "degreeTypes": [],
        "department": "",
        "derivedInfo": {
            "jobCategories": [],
            "locations": [
                {
                    "latLng": {
                        "latitude": "",
                        "longitude": ""
                    },
                    "locationType": "",
                    "postalAddress": {
                        "addressLines": [],
                        "administrativeArea": "",
                        "languageCode": "",
                        "locality": "",
                        "organization": "",
                        "postalCode": "",
                        "recipients": [],
                        "regionCode": "",
                        "revision": 0,
                        "sortingCode": "",
                        "sublocality": ""
                    },
                    "radiusInMiles": ""
                }
            ]
        },
        "description": "",
        "employmentTypes": [],
        "incentives": "",
        "jobBenefits": [],
        "jobEndTime": "",
        "jobLevel": "",
        "jobStartTime": "",
        "languageCode": "",
        "name": "",
        "postingCreateTime": "",
        "postingExpireTime": "",
        "postingPublishTime": "",
        "postingRegion": "",
        "postingUpdateTime": "",
        "processingOptions": {
            "disableStreetAddressResolution": False,
            "htmlSanitization": ""
        },
        "promotionValue": 0,
        "qualifications": "",
        "requisitionId": "",
        "responsibilities": "",
        "title": "",
        "visibility": ""
    } }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3p1beta1/:parent/jobs"

payload <- "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\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}}/v3p1beta1/:parent/jobs")

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  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\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/v3p1beta1/:parent/jobs') do |req|
  req.body = "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  }\n}"
end

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

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

    let payload = json!({"job": json!({
            "addresses": (),
            "applicationInfo": json!({
                "emails": (),
                "instruction": "",
                "uris": ()
            }),
            "companyDisplayName": "",
            "companyName": "",
            "compensationInfo": json!({
                "annualizedBaseCompensationRange": json!({
                    "maxCompensation": json!({
                        "currencyCode": "",
                        "nanos": 0,
                        "units": ""
                    }),
                    "minCompensation": json!({})
                }),
                "annualizedTotalCompensationRange": json!({}),
                "entries": (
                    json!({
                        "amount": json!({}),
                        "description": "",
                        "expectedUnitsPerYear": "",
                        "range": json!({}),
                        "type": "",
                        "unit": ""
                    })
                )
            }),
            "customAttributes": json!({}),
            "degreeTypes": (),
            "department": "",
            "derivedInfo": json!({
                "jobCategories": (),
                "locations": (
                    json!({
                        "latLng": json!({
                            "latitude": "",
                            "longitude": ""
                        }),
                        "locationType": "",
                        "postalAddress": json!({
                            "addressLines": (),
                            "administrativeArea": "",
                            "languageCode": "",
                            "locality": "",
                            "organization": "",
                            "postalCode": "",
                            "recipients": (),
                            "regionCode": "",
                            "revision": 0,
                            "sortingCode": "",
                            "sublocality": ""
                        }),
                        "radiusInMiles": ""
                    })
                )
            }),
            "description": "",
            "employmentTypes": (),
            "incentives": "",
            "jobBenefits": (),
            "jobEndTime": "",
            "jobLevel": "",
            "jobStartTime": "",
            "languageCode": "",
            "name": "",
            "postingCreateTime": "",
            "postingExpireTime": "",
            "postingPublishTime": "",
            "postingRegion": "",
            "postingUpdateTime": "",
            "processingOptions": json!({
                "disableStreetAddressResolution": false,
                "htmlSanitization": ""
            }),
            "promotionValue": 0,
            "qualifications": "",
            "requisitionId": "",
            "responsibilities": "",
            "title": "",
            "visibility": ""
        })});

    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}}/v3p1beta1/:parent/jobs \
  --header 'content-type: application/json' \
  --data '{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  }
}'
echo '{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  }
}' |  \
  http POST {{baseUrl}}/v3p1beta1/:parent/jobs \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "job": {\n    "addresses": [],\n    "applicationInfo": {\n      "emails": [],\n      "instruction": "",\n      "uris": []\n    },\n    "companyDisplayName": "",\n    "companyName": "",\n    "compensationInfo": {\n      "annualizedBaseCompensationRange": {\n        "maxCompensation": {\n          "currencyCode": "",\n          "nanos": 0,\n          "units": ""\n        },\n        "minCompensation": {}\n      },\n      "annualizedTotalCompensationRange": {},\n      "entries": [\n        {\n          "amount": {},\n          "description": "",\n          "expectedUnitsPerYear": "",\n          "range": {},\n          "type": "",\n          "unit": ""\n        }\n      ]\n    },\n    "customAttributes": {},\n    "degreeTypes": [],\n    "department": "",\n    "derivedInfo": {\n      "jobCategories": [],\n      "locations": [\n        {\n          "latLng": {\n            "latitude": "",\n            "longitude": ""\n          },\n          "locationType": "",\n          "postalAddress": {\n            "addressLines": [],\n            "administrativeArea": "",\n            "languageCode": "",\n            "locality": "",\n            "organization": "",\n            "postalCode": "",\n            "recipients": [],\n            "regionCode": "",\n            "revision": 0,\n            "sortingCode": "",\n            "sublocality": ""\n          },\n          "radiusInMiles": ""\n        }\n      ]\n    },\n    "description": "",\n    "employmentTypes": [],\n    "incentives": "",\n    "jobBenefits": [],\n    "jobEndTime": "",\n    "jobLevel": "",\n    "jobStartTime": "",\n    "languageCode": "",\n    "name": "",\n    "postingCreateTime": "",\n    "postingExpireTime": "",\n    "postingPublishTime": "",\n    "postingRegion": "",\n    "postingUpdateTime": "",\n    "processingOptions": {\n      "disableStreetAddressResolution": false,\n      "htmlSanitization": ""\n    },\n    "promotionValue": 0,\n    "qualifications": "",\n    "requisitionId": "",\n    "responsibilities": "",\n    "title": "",\n    "visibility": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:parent/jobs
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["job": [
    "addresses": [],
    "applicationInfo": [
      "emails": [],
      "instruction": "",
      "uris": []
    ],
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": [
      "annualizedBaseCompensationRange": [
        "maxCompensation": [
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        ],
        "minCompensation": []
      ],
      "annualizedTotalCompensationRange": [],
      "entries": [
        [
          "amount": [],
          "description": "",
          "expectedUnitsPerYear": "",
          "range": [],
          "type": "",
          "unit": ""
        ]
      ]
    ],
    "customAttributes": [],
    "degreeTypes": [],
    "department": "",
    "derivedInfo": [
      "jobCategories": [],
      "locations": [
        [
          "latLng": [
            "latitude": "",
            "longitude": ""
          ],
          "locationType": "",
          "postalAddress": [
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          ],
          "radiusInMiles": ""
        ]
      ]
    ],
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": [
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    ],
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  ]] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3p1beta1/:parent/jobs")! 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 jobs.projects.jobs.delete
{{baseUrl}}/v3p1beta1/: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}}/v3p1beta1/:name");

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

(client/delete "{{baseUrl}}/v3p1beta1/:name")
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/: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/v3p1beta1/:name HTTP/1.1
Host: example.com

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

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

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

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

const options = {method: 'DELETE', url: '{{baseUrl}}/v3p1beta1/:name'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/: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/v3p1beta1/: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}}/v3p1beta1/: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}}/v3p1beta1/: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}}/v3p1beta1/:name'};

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

const url = '{{baseUrl}}/v3p1beta1/: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}}/v3p1beta1/: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}}/v3p1beta1/:name" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v3p1beta1/:name');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

conn.request("DELETE", "/baseUrl/v3p1beta1/:name")

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

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

url = "{{baseUrl}}/v3p1beta1/:name"

response = requests.delete(url)

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

url <- "{{baseUrl}}/v3p1beta1/:name"

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

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

url = URI("{{baseUrl}}/v3p1beta1/: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/v3p1beta1/: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}}/v3p1beta1/: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}}/v3p1beta1/:name
http DELETE {{baseUrl}}/v3p1beta1/:name
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:name
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3p1beta1/: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 jobs.projects.jobs.list
{{baseUrl}}/v3p1beta1/:parent/jobs
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3p1beta1/:parent/jobs");

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

(client/get "{{baseUrl}}/v3p1beta1/:parent/jobs")
require "http/client"

url = "{{baseUrl}}/v3p1beta1/:parent/jobs"

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

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/:parent/jobs"

	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/v3p1beta1/:parent/jobs HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/jobs")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v3p1beta1/:parent/jobs")
  .asString();
const data = null;

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

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

xhr.open('GET', '{{baseUrl}}/v3p1beta1/:parent/jobs');

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

const options = {method: 'GET', url: '{{baseUrl}}/v3p1beta1/:parent/jobs'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/jobs")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3p1beta1/:parent/jobs',
  headers: {}
};

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v3p1beta1/:parent/jobs'};

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

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

const req = unirest('GET', '{{baseUrl}}/v3p1beta1/:parent/jobs');

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v3p1beta1/:parent/jobs'};

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

const url = '{{baseUrl}}/v3p1beta1/:parent/jobs';
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}}/v3p1beta1/:parent/jobs"]
                                                       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}}/v3p1beta1/:parent/jobs" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v3p1beta1/:parent/jobs');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v3p1beta1/:parent/jobs');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v3p1beta1/:parent/jobs' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3p1beta1/:parent/jobs' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v3p1beta1/:parent/jobs")

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

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

url = "{{baseUrl}}/v3p1beta1/:parent/jobs"

response = requests.get(url)

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

url <- "{{baseUrl}}/v3p1beta1/:parent/jobs"

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

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

url = URI("{{baseUrl}}/v3p1beta1/:parent/jobs")

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/v3p1beta1/:parent/jobs') do |req|
end

puts response.status
puts response.body
use reqwest;

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

    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}}/v3p1beta1/:parent/jobs
http GET {{baseUrl}}/v3p1beta1/:parent/jobs
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:parent/jobs
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3p1beta1/:parent/jobs")! 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()
PATCH jobs.projects.jobs.patch
{{baseUrl}}/v3p1beta1/:name
QUERY PARAMS

name
BODY json

{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  },
  "updateMask": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3p1beta1/:name");

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  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}");

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

(client/patch "{{baseUrl}}/v3p1beta1/:name" {:content-type :json
                                                             :form-params {:job {:addresses []
                                                                                 :applicationInfo {:emails []
                                                                                                   :instruction ""
                                                                                                   :uris []}
                                                                                 :companyDisplayName ""
                                                                                 :companyName ""
                                                                                 :compensationInfo {:annualizedBaseCompensationRange {:maxCompensation {:currencyCode ""
                                                                                                                                                        :nanos 0
                                                                                                                                                        :units ""}
                                                                                                                                      :minCompensation {}}
                                                                                                    :annualizedTotalCompensationRange {}
                                                                                                    :entries [{:amount {}
                                                                                                               :description ""
                                                                                                               :expectedUnitsPerYear ""
                                                                                                               :range {}
                                                                                                               :type ""
                                                                                                               :unit ""}]}
                                                                                 :customAttributes {}
                                                                                 :degreeTypes []
                                                                                 :department ""
                                                                                 :derivedInfo {:jobCategories []
                                                                                               :locations [{:latLng {:latitude ""
                                                                                                                     :longitude ""}
                                                                                                            :locationType ""
                                                                                                            :postalAddress {:addressLines []
                                                                                                                            :administrativeArea ""
                                                                                                                            :languageCode ""
                                                                                                                            :locality ""
                                                                                                                            :organization ""
                                                                                                                            :postalCode ""
                                                                                                                            :recipients []
                                                                                                                            :regionCode ""
                                                                                                                            :revision 0
                                                                                                                            :sortingCode ""
                                                                                                                            :sublocality ""}
                                                                                                            :radiusInMiles ""}]}
                                                                                 :description ""
                                                                                 :employmentTypes []
                                                                                 :incentives ""
                                                                                 :jobBenefits []
                                                                                 :jobEndTime ""
                                                                                 :jobLevel ""
                                                                                 :jobStartTime ""
                                                                                 :languageCode ""
                                                                                 :name ""
                                                                                 :postingCreateTime ""
                                                                                 :postingExpireTime ""
                                                                                 :postingPublishTime ""
                                                                                 :postingRegion ""
                                                                                 :postingUpdateTime ""
                                                                                 :processingOptions {:disableStreetAddressResolution false
                                                                                                     :htmlSanitization ""}
                                                                                 :promotionValue 0
                                                                                 :qualifications ""
                                                                                 :requisitionId ""
                                                                                 :responsibilities ""
                                                                                 :title ""
                                                                                 :visibility ""}
                                                                           :updateMask ""}})
require "http/client"

url = "{{baseUrl}}/v3p1beta1/:name"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}"

response = HTTP::Client.patch url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Patch,
    RequestUri = new Uri("{{baseUrl}}/v3p1beta1/:name"),
    Content = new StringContent("{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3p1beta1/:name");
var request = new RestRequest("", Method.Patch);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/:name"

	payload := strings.NewReader("{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}")

	req, _ := http.NewRequest("PATCH", 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))

}
PATCH /baseUrl/v3p1beta1/:name HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1990

{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  },
  "updateMask": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/v3p1beta1/:name")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3p1beta1/:name"))
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:name")
  .patch(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/v3p1beta1/:name")
  .header("content-type", "application/json")
  .body("{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  job: {
    addresses: [],
    applicationInfo: {
      emails: [],
      instruction: '',
      uris: []
    },
    companyDisplayName: '',
    companyName: '',
    compensationInfo: {
      annualizedBaseCompensationRange: {
        maxCompensation: {
          currencyCode: '',
          nanos: 0,
          units: ''
        },
        minCompensation: {}
      },
      annualizedTotalCompensationRange: {},
      entries: [
        {
          amount: {},
          description: '',
          expectedUnitsPerYear: '',
          range: {},
          type: '',
          unit: ''
        }
      ]
    },
    customAttributes: {},
    degreeTypes: [],
    department: '',
    derivedInfo: {
      jobCategories: [],
      locations: [
        {
          latLng: {
            latitude: '',
            longitude: ''
          },
          locationType: '',
          postalAddress: {
            addressLines: [],
            administrativeArea: '',
            languageCode: '',
            locality: '',
            organization: '',
            postalCode: '',
            recipients: [],
            regionCode: '',
            revision: 0,
            sortingCode: '',
            sublocality: ''
          },
          radiusInMiles: ''
        }
      ]
    },
    description: '',
    employmentTypes: [],
    incentives: '',
    jobBenefits: [],
    jobEndTime: '',
    jobLevel: '',
    jobStartTime: '',
    languageCode: '',
    name: '',
    postingCreateTime: '',
    postingExpireTime: '',
    postingPublishTime: '',
    postingRegion: '',
    postingUpdateTime: '',
    processingOptions: {
      disableStreetAddressResolution: false,
      htmlSanitization: ''
    },
    promotionValue: 0,
    qualifications: '',
    requisitionId: '',
    responsibilities: '',
    title: '',
    visibility: ''
  },
  updateMask: ''
});

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

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

xhr.open('PATCH', '{{baseUrl}}/v3p1beta1/:name');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/v3p1beta1/:name',
  headers: {'content-type': 'application/json'},
  data: {
    job: {
      addresses: [],
      applicationInfo: {emails: [], instruction: '', uris: []},
      companyDisplayName: '',
      companyName: '',
      compensationInfo: {
        annualizedBaseCompensationRange: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        annualizedTotalCompensationRange: {},
        entries: [
          {
            amount: {},
            description: '',
            expectedUnitsPerYear: '',
            range: {},
            type: '',
            unit: ''
          }
        ]
      },
      customAttributes: {},
      degreeTypes: [],
      department: '',
      derivedInfo: {
        jobCategories: [],
        locations: [
          {
            latLng: {latitude: '', longitude: ''},
            locationType: '',
            postalAddress: {
              addressLines: [],
              administrativeArea: '',
              languageCode: '',
              locality: '',
              organization: '',
              postalCode: '',
              recipients: [],
              regionCode: '',
              revision: 0,
              sortingCode: '',
              sublocality: ''
            },
            radiusInMiles: ''
          }
        ]
      },
      description: '',
      employmentTypes: [],
      incentives: '',
      jobBenefits: [],
      jobEndTime: '',
      jobLevel: '',
      jobStartTime: '',
      languageCode: '',
      name: '',
      postingCreateTime: '',
      postingExpireTime: '',
      postingPublishTime: '',
      postingRegion: '',
      postingUpdateTime: '',
      processingOptions: {disableStreetAddressResolution: false, htmlSanitization: ''},
      promotionValue: 0,
      qualifications: '',
      requisitionId: '',
      responsibilities: '',
      title: '',
      visibility: ''
    },
    updateMask: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3p1beta1/:name';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"job":{"addresses":[],"applicationInfo":{"emails":[],"instruction":"","uris":[]},"companyDisplayName":"","companyName":"","compensationInfo":{"annualizedBaseCompensationRange":{"maxCompensation":{"currencyCode":"","nanos":0,"units":""},"minCompensation":{}},"annualizedTotalCompensationRange":{},"entries":[{"amount":{},"description":"","expectedUnitsPerYear":"","range":{},"type":"","unit":""}]},"customAttributes":{},"degreeTypes":[],"department":"","derivedInfo":{"jobCategories":[],"locations":[{"latLng":{"latitude":"","longitude":""},"locationType":"","postalAddress":{"addressLines":[],"administrativeArea":"","languageCode":"","locality":"","organization":"","postalCode":"","recipients":[],"regionCode":"","revision":0,"sortingCode":"","sublocality":""},"radiusInMiles":""}]},"description":"","employmentTypes":[],"incentives":"","jobBenefits":[],"jobEndTime":"","jobLevel":"","jobStartTime":"","languageCode":"","name":"","postingCreateTime":"","postingExpireTime":"","postingPublishTime":"","postingRegion":"","postingUpdateTime":"","processingOptions":{"disableStreetAddressResolution":false,"htmlSanitization":""},"promotionValue":0,"qualifications":"","requisitionId":"","responsibilities":"","title":"","visibility":""},"updateMask":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v3p1beta1/:name',
  method: 'PATCH',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "job": {\n    "addresses": [],\n    "applicationInfo": {\n      "emails": [],\n      "instruction": "",\n      "uris": []\n    },\n    "companyDisplayName": "",\n    "companyName": "",\n    "compensationInfo": {\n      "annualizedBaseCompensationRange": {\n        "maxCompensation": {\n          "currencyCode": "",\n          "nanos": 0,\n          "units": ""\n        },\n        "minCompensation": {}\n      },\n      "annualizedTotalCompensationRange": {},\n      "entries": [\n        {\n          "amount": {},\n          "description": "",\n          "expectedUnitsPerYear": "",\n          "range": {},\n          "type": "",\n          "unit": ""\n        }\n      ]\n    },\n    "customAttributes": {},\n    "degreeTypes": [],\n    "department": "",\n    "derivedInfo": {\n      "jobCategories": [],\n      "locations": [\n        {\n          "latLng": {\n            "latitude": "",\n            "longitude": ""\n          },\n          "locationType": "",\n          "postalAddress": {\n            "addressLines": [],\n            "administrativeArea": "",\n            "languageCode": "",\n            "locality": "",\n            "organization": "",\n            "postalCode": "",\n            "recipients": [],\n            "regionCode": "",\n            "revision": 0,\n            "sortingCode": "",\n            "sublocality": ""\n          },\n          "radiusInMiles": ""\n        }\n      ]\n    },\n    "description": "",\n    "employmentTypes": [],\n    "incentives": "",\n    "jobBenefits": [],\n    "jobEndTime": "",\n    "jobLevel": "",\n    "jobStartTime": "",\n    "languageCode": "",\n    "name": "",\n    "postingCreateTime": "",\n    "postingExpireTime": "",\n    "postingPublishTime": "",\n    "postingRegion": "",\n    "postingUpdateTime": "",\n    "processingOptions": {\n      "disableStreetAddressResolution": false,\n      "htmlSanitization": ""\n    },\n    "promotionValue": 0,\n    "qualifications": "",\n    "requisitionId": "",\n    "responsibilities": "",\n    "title": "",\n    "visibility": ""\n  },\n  "updateMask": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:name")
  .patch(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'PATCH',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3p1beta1/:name',
  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({
  job: {
    addresses: [],
    applicationInfo: {emails: [], instruction: '', uris: []},
    companyDisplayName: '',
    companyName: '',
    compensationInfo: {
      annualizedBaseCompensationRange: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
      annualizedTotalCompensationRange: {},
      entries: [
        {
          amount: {},
          description: '',
          expectedUnitsPerYear: '',
          range: {},
          type: '',
          unit: ''
        }
      ]
    },
    customAttributes: {},
    degreeTypes: [],
    department: '',
    derivedInfo: {
      jobCategories: [],
      locations: [
        {
          latLng: {latitude: '', longitude: ''},
          locationType: '',
          postalAddress: {
            addressLines: [],
            administrativeArea: '',
            languageCode: '',
            locality: '',
            organization: '',
            postalCode: '',
            recipients: [],
            regionCode: '',
            revision: 0,
            sortingCode: '',
            sublocality: ''
          },
          radiusInMiles: ''
        }
      ]
    },
    description: '',
    employmentTypes: [],
    incentives: '',
    jobBenefits: [],
    jobEndTime: '',
    jobLevel: '',
    jobStartTime: '',
    languageCode: '',
    name: '',
    postingCreateTime: '',
    postingExpireTime: '',
    postingPublishTime: '',
    postingRegion: '',
    postingUpdateTime: '',
    processingOptions: {disableStreetAddressResolution: false, htmlSanitization: ''},
    promotionValue: 0,
    qualifications: '',
    requisitionId: '',
    responsibilities: '',
    title: '',
    visibility: ''
  },
  updateMask: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/v3p1beta1/:name',
  headers: {'content-type': 'application/json'},
  body: {
    job: {
      addresses: [],
      applicationInfo: {emails: [], instruction: '', uris: []},
      companyDisplayName: '',
      companyName: '',
      compensationInfo: {
        annualizedBaseCompensationRange: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        annualizedTotalCompensationRange: {},
        entries: [
          {
            amount: {},
            description: '',
            expectedUnitsPerYear: '',
            range: {},
            type: '',
            unit: ''
          }
        ]
      },
      customAttributes: {},
      degreeTypes: [],
      department: '',
      derivedInfo: {
        jobCategories: [],
        locations: [
          {
            latLng: {latitude: '', longitude: ''},
            locationType: '',
            postalAddress: {
              addressLines: [],
              administrativeArea: '',
              languageCode: '',
              locality: '',
              organization: '',
              postalCode: '',
              recipients: [],
              regionCode: '',
              revision: 0,
              sortingCode: '',
              sublocality: ''
            },
            radiusInMiles: ''
          }
        ]
      },
      description: '',
      employmentTypes: [],
      incentives: '',
      jobBenefits: [],
      jobEndTime: '',
      jobLevel: '',
      jobStartTime: '',
      languageCode: '',
      name: '',
      postingCreateTime: '',
      postingExpireTime: '',
      postingPublishTime: '',
      postingRegion: '',
      postingUpdateTime: '',
      processingOptions: {disableStreetAddressResolution: false, htmlSanitization: ''},
      promotionValue: 0,
      qualifications: '',
      requisitionId: '',
      responsibilities: '',
      title: '',
      visibility: ''
    },
    updateMask: ''
  },
  json: true
};

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

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

const req = unirest('PATCH', '{{baseUrl}}/v3p1beta1/:name');

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

req.type('json');
req.send({
  job: {
    addresses: [],
    applicationInfo: {
      emails: [],
      instruction: '',
      uris: []
    },
    companyDisplayName: '',
    companyName: '',
    compensationInfo: {
      annualizedBaseCompensationRange: {
        maxCompensation: {
          currencyCode: '',
          nanos: 0,
          units: ''
        },
        minCompensation: {}
      },
      annualizedTotalCompensationRange: {},
      entries: [
        {
          amount: {},
          description: '',
          expectedUnitsPerYear: '',
          range: {},
          type: '',
          unit: ''
        }
      ]
    },
    customAttributes: {},
    degreeTypes: [],
    department: '',
    derivedInfo: {
      jobCategories: [],
      locations: [
        {
          latLng: {
            latitude: '',
            longitude: ''
          },
          locationType: '',
          postalAddress: {
            addressLines: [],
            administrativeArea: '',
            languageCode: '',
            locality: '',
            organization: '',
            postalCode: '',
            recipients: [],
            regionCode: '',
            revision: 0,
            sortingCode: '',
            sublocality: ''
          },
          radiusInMiles: ''
        }
      ]
    },
    description: '',
    employmentTypes: [],
    incentives: '',
    jobBenefits: [],
    jobEndTime: '',
    jobLevel: '',
    jobStartTime: '',
    languageCode: '',
    name: '',
    postingCreateTime: '',
    postingExpireTime: '',
    postingPublishTime: '',
    postingRegion: '',
    postingUpdateTime: '',
    processingOptions: {
      disableStreetAddressResolution: false,
      htmlSanitization: ''
    },
    promotionValue: 0,
    qualifications: '',
    requisitionId: '',
    responsibilities: '',
    title: '',
    visibility: ''
  },
  updateMask: ''
});

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

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/v3p1beta1/:name',
  headers: {'content-type': 'application/json'},
  data: {
    job: {
      addresses: [],
      applicationInfo: {emails: [], instruction: '', uris: []},
      companyDisplayName: '',
      companyName: '',
      compensationInfo: {
        annualizedBaseCompensationRange: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        annualizedTotalCompensationRange: {},
        entries: [
          {
            amount: {},
            description: '',
            expectedUnitsPerYear: '',
            range: {},
            type: '',
            unit: ''
          }
        ]
      },
      customAttributes: {},
      degreeTypes: [],
      department: '',
      derivedInfo: {
        jobCategories: [],
        locations: [
          {
            latLng: {latitude: '', longitude: ''},
            locationType: '',
            postalAddress: {
              addressLines: [],
              administrativeArea: '',
              languageCode: '',
              locality: '',
              organization: '',
              postalCode: '',
              recipients: [],
              regionCode: '',
              revision: 0,
              sortingCode: '',
              sublocality: ''
            },
            radiusInMiles: ''
          }
        ]
      },
      description: '',
      employmentTypes: [],
      incentives: '',
      jobBenefits: [],
      jobEndTime: '',
      jobLevel: '',
      jobStartTime: '',
      languageCode: '',
      name: '',
      postingCreateTime: '',
      postingExpireTime: '',
      postingPublishTime: '',
      postingRegion: '',
      postingUpdateTime: '',
      processingOptions: {disableStreetAddressResolution: false, htmlSanitization: ''},
      promotionValue: 0,
      qualifications: '',
      requisitionId: '',
      responsibilities: '',
      title: '',
      visibility: ''
    },
    updateMask: ''
  }
};

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

const url = '{{baseUrl}}/v3p1beta1/:name';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"job":{"addresses":[],"applicationInfo":{"emails":[],"instruction":"","uris":[]},"companyDisplayName":"","companyName":"","compensationInfo":{"annualizedBaseCompensationRange":{"maxCompensation":{"currencyCode":"","nanos":0,"units":""},"minCompensation":{}},"annualizedTotalCompensationRange":{},"entries":[{"amount":{},"description":"","expectedUnitsPerYear":"","range":{},"type":"","unit":""}]},"customAttributes":{},"degreeTypes":[],"department":"","derivedInfo":{"jobCategories":[],"locations":[{"latLng":{"latitude":"","longitude":""},"locationType":"","postalAddress":{"addressLines":[],"administrativeArea":"","languageCode":"","locality":"","organization":"","postalCode":"","recipients":[],"regionCode":"","revision":0,"sortingCode":"","sublocality":""},"radiusInMiles":""}]},"description":"","employmentTypes":[],"incentives":"","jobBenefits":[],"jobEndTime":"","jobLevel":"","jobStartTime":"","languageCode":"","name":"","postingCreateTime":"","postingExpireTime":"","postingPublishTime":"","postingRegion":"","postingUpdateTime":"","processingOptions":{"disableStreetAddressResolution":false,"htmlSanitization":""},"promotionValue":0,"qualifications":"","requisitionId":"","responsibilities":"","title":"","visibility":""},"updateMask":""}'
};

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 = @{ @"job": @{ @"addresses": @[  ], @"applicationInfo": @{ @"emails": @[  ], @"instruction": @"", @"uris": @[  ] }, @"companyDisplayName": @"", @"companyName": @"", @"compensationInfo": @{ @"annualizedBaseCompensationRange": @{ @"maxCompensation": @{ @"currencyCode": @"", @"nanos": @0, @"units": @"" }, @"minCompensation": @{  } }, @"annualizedTotalCompensationRange": @{  }, @"entries": @[ @{ @"amount": @{  }, @"description": @"", @"expectedUnitsPerYear": @"", @"range": @{  }, @"type": @"", @"unit": @"" } ] }, @"customAttributes": @{  }, @"degreeTypes": @[  ], @"department": @"", @"derivedInfo": @{ @"jobCategories": @[  ], @"locations": @[ @{ @"latLng": @{ @"latitude": @"", @"longitude": @"" }, @"locationType": @"", @"postalAddress": @{ @"addressLines": @[  ], @"administrativeArea": @"", @"languageCode": @"", @"locality": @"", @"organization": @"", @"postalCode": @"", @"recipients": @[  ], @"regionCode": @"", @"revision": @0, @"sortingCode": @"", @"sublocality": @"" }, @"radiusInMiles": @"" } ] }, @"description": @"", @"employmentTypes": @[  ], @"incentives": @"", @"jobBenefits": @[  ], @"jobEndTime": @"", @"jobLevel": @"", @"jobStartTime": @"", @"languageCode": @"", @"name": @"", @"postingCreateTime": @"", @"postingExpireTime": @"", @"postingPublishTime": @"", @"postingRegion": @"", @"postingUpdateTime": @"", @"processingOptions": @{ @"disableStreetAddressResolution": @NO, @"htmlSanitization": @"" }, @"promotionValue": @0, @"qualifications": @"", @"requisitionId": @"", @"responsibilities": @"", @"title": @"", @"visibility": @"" },
                              @"updateMask": @"" };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v3p1beta1/:name" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3p1beta1/:name",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PATCH",
  CURLOPT_POSTFIELDS => json_encode([
    'job' => [
        'addresses' => [
                
        ],
        'applicationInfo' => [
                'emails' => [
                                
                ],
                'instruction' => '',
                'uris' => [
                                
                ]
        ],
        'companyDisplayName' => '',
        'companyName' => '',
        'compensationInfo' => [
                'annualizedBaseCompensationRange' => [
                                'maxCompensation' => [
                                                                'currencyCode' => '',
                                                                'nanos' => 0,
                                                                'units' => ''
                                ],
                                'minCompensation' => [
                                                                
                                ]
                ],
                'annualizedTotalCompensationRange' => [
                                
                ],
                'entries' => [
                                [
                                                                'amount' => [
                                                                                                                                
                                                                ],
                                                                'description' => '',
                                                                'expectedUnitsPerYear' => '',
                                                                'range' => [
                                                                                                                                
                                                                ],
                                                                'type' => '',
                                                                'unit' => ''
                                ]
                ]
        ],
        'customAttributes' => [
                
        ],
        'degreeTypes' => [
                
        ],
        'department' => '',
        'derivedInfo' => [
                'jobCategories' => [
                                
                ],
                'locations' => [
                                [
                                                                'latLng' => [
                                                                                                                                'latitude' => '',
                                                                                                                                'longitude' => ''
                                                                ],
                                                                'locationType' => '',
                                                                'postalAddress' => [
                                                                                                                                'addressLines' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'administrativeArea' => '',
                                                                                                                                'languageCode' => '',
                                                                                                                                'locality' => '',
                                                                                                                                'organization' => '',
                                                                                                                                'postalCode' => '',
                                                                                                                                'recipients' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'regionCode' => '',
                                                                                                                                'revision' => 0,
                                                                                                                                'sortingCode' => '',
                                                                                                                                'sublocality' => ''
                                                                ],
                                                                'radiusInMiles' => ''
                                ]
                ]
        ],
        'description' => '',
        'employmentTypes' => [
                
        ],
        'incentives' => '',
        'jobBenefits' => [
                
        ],
        'jobEndTime' => '',
        'jobLevel' => '',
        'jobStartTime' => '',
        'languageCode' => '',
        'name' => '',
        'postingCreateTime' => '',
        'postingExpireTime' => '',
        'postingPublishTime' => '',
        'postingRegion' => '',
        'postingUpdateTime' => '',
        'processingOptions' => [
                'disableStreetAddressResolution' => null,
                'htmlSanitization' => ''
        ],
        'promotionValue' => 0,
        'qualifications' => '',
        'requisitionId' => '',
        'responsibilities' => '',
        'title' => '',
        'visibility' => ''
    ],
    'updateMask' => ''
  ]),
  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('PATCH', '{{baseUrl}}/v3p1beta1/:name', [
  'body' => '{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  },
  "updateMask": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'job' => [
    'addresses' => [
        
    ],
    'applicationInfo' => [
        'emails' => [
                
        ],
        'instruction' => '',
        'uris' => [
                
        ]
    ],
    'companyDisplayName' => '',
    'companyName' => '',
    'compensationInfo' => [
        'annualizedBaseCompensationRange' => [
                'maxCompensation' => [
                                'currencyCode' => '',
                                'nanos' => 0,
                                'units' => ''
                ],
                'minCompensation' => [
                                
                ]
        ],
        'annualizedTotalCompensationRange' => [
                
        ],
        'entries' => [
                [
                                'amount' => [
                                                                
                                ],
                                'description' => '',
                                'expectedUnitsPerYear' => '',
                                'range' => [
                                                                
                                ],
                                'type' => '',
                                'unit' => ''
                ]
        ]
    ],
    'customAttributes' => [
        
    ],
    'degreeTypes' => [
        
    ],
    'department' => '',
    'derivedInfo' => [
        'jobCategories' => [
                
        ],
        'locations' => [
                [
                                'latLng' => [
                                                                'latitude' => '',
                                                                'longitude' => ''
                                ],
                                'locationType' => '',
                                'postalAddress' => [
                                                                'addressLines' => [
                                                                                                                                
                                                                ],
                                                                'administrativeArea' => '',
                                                                'languageCode' => '',
                                                                'locality' => '',
                                                                'organization' => '',
                                                                'postalCode' => '',
                                                                'recipients' => [
                                                                                                                                
                                                                ],
                                                                'regionCode' => '',
                                                                'revision' => 0,
                                                                'sortingCode' => '',
                                                                'sublocality' => ''
                                ],
                                'radiusInMiles' => ''
                ]
        ]
    ],
    'description' => '',
    'employmentTypes' => [
        
    ],
    'incentives' => '',
    'jobBenefits' => [
        
    ],
    'jobEndTime' => '',
    'jobLevel' => '',
    'jobStartTime' => '',
    'languageCode' => '',
    'name' => '',
    'postingCreateTime' => '',
    'postingExpireTime' => '',
    'postingPublishTime' => '',
    'postingRegion' => '',
    'postingUpdateTime' => '',
    'processingOptions' => [
        'disableStreetAddressResolution' => null,
        'htmlSanitization' => ''
    ],
    'promotionValue' => 0,
    'qualifications' => '',
    'requisitionId' => '',
    'responsibilities' => '',
    'title' => '',
    'visibility' => ''
  ],
  'updateMask' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'job' => [
    'addresses' => [
        
    ],
    'applicationInfo' => [
        'emails' => [
                
        ],
        'instruction' => '',
        'uris' => [
                
        ]
    ],
    'companyDisplayName' => '',
    'companyName' => '',
    'compensationInfo' => [
        'annualizedBaseCompensationRange' => [
                'maxCompensation' => [
                                'currencyCode' => '',
                                'nanos' => 0,
                                'units' => ''
                ],
                'minCompensation' => [
                                
                ]
        ],
        'annualizedTotalCompensationRange' => [
                
        ],
        'entries' => [
                [
                                'amount' => [
                                                                
                                ],
                                'description' => '',
                                'expectedUnitsPerYear' => '',
                                'range' => [
                                                                
                                ],
                                'type' => '',
                                'unit' => ''
                ]
        ]
    ],
    'customAttributes' => [
        
    ],
    'degreeTypes' => [
        
    ],
    'department' => '',
    'derivedInfo' => [
        'jobCategories' => [
                
        ],
        'locations' => [
                [
                                'latLng' => [
                                                                'latitude' => '',
                                                                'longitude' => ''
                                ],
                                'locationType' => '',
                                'postalAddress' => [
                                                                'addressLines' => [
                                                                                                                                
                                                                ],
                                                                'administrativeArea' => '',
                                                                'languageCode' => '',
                                                                'locality' => '',
                                                                'organization' => '',
                                                                'postalCode' => '',
                                                                'recipients' => [
                                                                                                                                
                                                                ],
                                                                'regionCode' => '',
                                                                'revision' => 0,
                                                                'sortingCode' => '',
                                                                'sublocality' => ''
                                ],
                                'radiusInMiles' => ''
                ]
        ]
    ],
    'description' => '',
    'employmentTypes' => [
        
    ],
    'incentives' => '',
    'jobBenefits' => [
        
    ],
    'jobEndTime' => '',
    'jobLevel' => '',
    'jobStartTime' => '',
    'languageCode' => '',
    'name' => '',
    'postingCreateTime' => '',
    'postingExpireTime' => '',
    'postingPublishTime' => '',
    'postingRegion' => '',
    'postingUpdateTime' => '',
    'processingOptions' => [
        'disableStreetAddressResolution' => null,
        'htmlSanitization' => ''
    ],
    'promotionValue' => 0,
    'qualifications' => '',
    'requisitionId' => '',
    'responsibilities' => '',
    'title' => '',
    'visibility' => ''
  ],
  'updateMask' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3p1beta1/:name');
$request->setRequestMethod('PATCH');
$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}}/v3p1beta1/:name' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  },
  "updateMask": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3p1beta1/:name' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  },
  "updateMask": ""
}'
import http.client

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

payload = "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}"

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

conn.request("PATCH", "/baseUrl/v3p1beta1/:name", payload, headers)

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

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

url = "{{baseUrl}}/v3p1beta1/:name"

payload = {
    "job": {
        "addresses": [],
        "applicationInfo": {
            "emails": [],
            "instruction": "",
            "uris": []
        },
        "companyDisplayName": "",
        "companyName": "",
        "compensationInfo": {
            "annualizedBaseCompensationRange": {
                "maxCompensation": {
                    "currencyCode": "",
                    "nanos": 0,
                    "units": ""
                },
                "minCompensation": {}
            },
            "annualizedTotalCompensationRange": {},
            "entries": [
                {
                    "amount": {},
                    "description": "",
                    "expectedUnitsPerYear": "",
                    "range": {},
                    "type": "",
                    "unit": ""
                }
            ]
        },
        "customAttributes": {},
        "degreeTypes": [],
        "department": "",
        "derivedInfo": {
            "jobCategories": [],
            "locations": [
                {
                    "latLng": {
                        "latitude": "",
                        "longitude": ""
                    },
                    "locationType": "",
                    "postalAddress": {
                        "addressLines": [],
                        "administrativeArea": "",
                        "languageCode": "",
                        "locality": "",
                        "organization": "",
                        "postalCode": "",
                        "recipients": [],
                        "regionCode": "",
                        "revision": 0,
                        "sortingCode": "",
                        "sublocality": ""
                    },
                    "radiusInMiles": ""
                }
            ]
        },
        "description": "",
        "employmentTypes": [],
        "incentives": "",
        "jobBenefits": [],
        "jobEndTime": "",
        "jobLevel": "",
        "jobStartTime": "",
        "languageCode": "",
        "name": "",
        "postingCreateTime": "",
        "postingExpireTime": "",
        "postingPublishTime": "",
        "postingRegion": "",
        "postingUpdateTime": "",
        "processingOptions": {
            "disableStreetAddressResolution": False,
            "htmlSanitization": ""
        },
        "promotionValue": 0,
        "qualifications": "",
        "requisitionId": "",
        "responsibilities": "",
        "title": "",
        "visibility": ""
    },
    "updateMask": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3p1beta1/:name"

payload <- "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v3p1beta1/:name")

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

request = Net::HTTP::Patch.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\n}"

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

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

response = conn.patch('/baseUrl/v3p1beta1/:name') do |req|
  req.body = "{\n  \"job\": {\n    \"addresses\": [],\n    \"applicationInfo\": {\n      \"emails\": [],\n      \"instruction\": \"\",\n      \"uris\": []\n    },\n    \"companyDisplayName\": \"\",\n    \"companyName\": \"\",\n    \"compensationInfo\": {\n      \"annualizedBaseCompensationRange\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"annualizedTotalCompensationRange\": {},\n      \"entries\": [\n        {\n          \"amount\": {},\n          \"description\": \"\",\n          \"expectedUnitsPerYear\": \"\",\n          \"range\": {},\n          \"type\": \"\",\n          \"unit\": \"\"\n        }\n      ]\n    },\n    \"customAttributes\": {},\n    \"degreeTypes\": [],\n    \"department\": \"\",\n    \"derivedInfo\": {\n      \"jobCategories\": [],\n      \"locations\": [\n        {\n          \"latLng\": {\n            \"latitude\": \"\",\n            \"longitude\": \"\"\n          },\n          \"locationType\": \"\",\n          \"postalAddress\": {\n            \"addressLines\": [],\n            \"administrativeArea\": \"\",\n            \"languageCode\": \"\",\n            \"locality\": \"\",\n            \"organization\": \"\",\n            \"postalCode\": \"\",\n            \"recipients\": [],\n            \"regionCode\": \"\",\n            \"revision\": 0,\n            \"sortingCode\": \"\",\n            \"sublocality\": \"\"\n          },\n          \"radiusInMiles\": \"\"\n        }\n      ]\n    },\n    \"description\": \"\",\n    \"employmentTypes\": [],\n    \"incentives\": \"\",\n    \"jobBenefits\": [],\n    \"jobEndTime\": \"\",\n    \"jobLevel\": \"\",\n    \"jobStartTime\": \"\",\n    \"languageCode\": \"\",\n    \"name\": \"\",\n    \"postingCreateTime\": \"\",\n    \"postingExpireTime\": \"\",\n    \"postingPublishTime\": \"\",\n    \"postingRegion\": \"\",\n    \"postingUpdateTime\": \"\",\n    \"processingOptions\": {\n      \"disableStreetAddressResolution\": false,\n      \"htmlSanitization\": \"\"\n    },\n    \"promotionValue\": 0,\n    \"qualifications\": \"\",\n    \"requisitionId\": \"\",\n    \"responsibilities\": \"\",\n    \"title\": \"\",\n    \"visibility\": \"\"\n  },\n  \"updateMask\": \"\"\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}}/v3p1beta1/:name";

    let payload = json!({
        "job": json!({
            "addresses": (),
            "applicationInfo": json!({
                "emails": (),
                "instruction": "",
                "uris": ()
            }),
            "companyDisplayName": "",
            "companyName": "",
            "compensationInfo": json!({
                "annualizedBaseCompensationRange": json!({
                    "maxCompensation": json!({
                        "currencyCode": "",
                        "nanos": 0,
                        "units": ""
                    }),
                    "minCompensation": json!({})
                }),
                "annualizedTotalCompensationRange": json!({}),
                "entries": (
                    json!({
                        "amount": json!({}),
                        "description": "",
                        "expectedUnitsPerYear": "",
                        "range": json!({}),
                        "type": "",
                        "unit": ""
                    })
                )
            }),
            "customAttributes": json!({}),
            "degreeTypes": (),
            "department": "",
            "derivedInfo": json!({
                "jobCategories": (),
                "locations": (
                    json!({
                        "latLng": json!({
                            "latitude": "",
                            "longitude": ""
                        }),
                        "locationType": "",
                        "postalAddress": json!({
                            "addressLines": (),
                            "administrativeArea": "",
                            "languageCode": "",
                            "locality": "",
                            "organization": "",
                            "postalCode": "",
                            "recipients": (),
                            "regionCode": "",
                            "revision": 0,
                            "sortingCode": "",
                            "sublocality": ""
                        }),
                        "radiusInMiles": ""
                    })
                )
            }),
            "description": "",
            "employmentTypes": (),
            "incentives": "",
            "jobBenefits": (),
            "jobEndTime": "",
            "jobLevel": "",
            "jobStartTime": "",
            "languageCode": "",
            "name": "",
            "postingCreateTime": "",
            "postingExpireTime": "",
            "postingPublishTime": "",
            "postingRegion": "",
            "postingUpdateTime": "",
            "processingOptions": json!({
                "disableStreetAddressResolution": false,
                "htmlSanitization": ""
            }),
            "promotionValue": 0,
            "qualifications": "",
            "requisitionId": "",
            "responsibilities": "",
            "title": "",
            "visibility": ""
        }),
        "updateMask": ""
    });

    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("PATCH").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

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

    dbg!(results);
}
curl --request PATCH \
  --url {{baseUrl}}/v3p1beta1/:name \
  --header 'content-type: application/json' \
  --data '{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  },
  "updateMask": ""
}'
echo '{
  "job": {
    "addresses": [],
    "applicationInfo": {
      "emails": [],
      "instruction": "",
      "uris": []
    },
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": {
      "annualizedBaseCompensationRange": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "annualizedTotalCompensationRange": {},
      "entries": [
        {
          "amount": {},
          "description": "",
          "expectedUnitsPerYear": "",
          "range": {},
          "type": "",
          "unit": ""
        }
      ]
    },
    "customAttributes": {},
    "degreeTypes": [],
    "department": "",
    "derivedInfo": {
      "jobCategories": [],
      "locations": [
        {
          "latLng": {
            "latitude": "",
            "longitude": ""
          },
          "locationType": "",
          "postalAddress": {
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          },
          "radiusInMiles": ""
        }
      ]
    },
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": {
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    },
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  },
  "updateMask": ""
}' |  \
  http PATCH {{baseUrl}}/v3p1beta1/:name \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'content-type: application/json' \
  --body-data '{\n  "job": {\n    "addresses": [],\n    "applicationInfo": {\n      "emails": [],\n      "instruction": "",\n      "uris": []\n    },\n    "companyDisplayName": "",\n    "companyName": "",\n    "compensationInfo": {\n      "annualizedBaseCompensationRange": {\n        "maxCompensation": {\n          "currencyCode": "",\n          "nanos": 0,\n          "units": ""\n        },\n        "minCompensation": {}\n      },\n      "annualizedTotalCompensationRange": {},\n      "entries": [\n        {\n          "amount": {},\n          "description": "",\n          "expectedUnitsPerYear": "",\n          "range": {},\n          "type": "",\n          "unit": ""\n        }\n      ]\n    },\n    "customAttributes": {},\n    "degreeTypes": [],\n    "department": "",\n    "derivedInfo": {\n      "jobCategories": [],\n      "locations": [\n        {\n          "latLng": {\n            "latitude": "",\n            "longitude": ""\n          },\n          "locationType": "",\n          "postalAddress": {\n            "addressLines": [],\n            "administrativeArea": "",\n            "languageCode": "",\n            "locality": "",\n            "organization": "",\n            "postalCode": "",\n            "recipients": [],\n            "regionCode": "",\n            "revision": 0,\n            "sortingCode": "",\n            "sublocality": ""\n          },\n          "radiusInMiles": ""\n        }\n      ]\n    },\n    "description": "",\n    "employmentTypes": [],\n    "incentives": "",\n    "jobBenefits": [],\n    "jobEndTime": "",\n    "jobLevel": "",\n    "jobStartTime": "",\n    "languageCode": "",\n    "name": "",\n    "postingCreateTime": "",\n    "postingExpireTime": "",\n    "postingPublishTime": "",\n    "postingRegion": "",\n    "postingUpdateTime": "",\n    "processingOptions": {\n      "disableStreetAddressResolution": false,\n      "htmlSanitization": ""\n    },\n    "promotionValue": 0,\n    "qualifications": "",\n    "requisitionId": "",\n    "responsibilities": "",\n    "title": "",\n    "visibility": ""\n  },\n  "updateMask": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:name
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "job": [
    "addresses": [],
    "applicationInfo": [
      "emails": [],
      "instruction": "",
      "uris": []
    ],
    "companyDisplayName": "",
    "companyName": "",
    "compensationInfo": [
      "annualizedBaseCompensationRange": [
        "maxCompensation": [
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        ],
        "minCompensation": []
      ],
      "annualizedTotalCompensationRange": [],
      "entries": [
        [
          "amount": [],
          "description": "",
          "expectedUnitsPerYear": "",
          "range": [],
          "type": "",
          "unit": ""
        ]
      ]
    ],
    "customAttributes": [],
    "degreeTypes": [],
    "department": "",
    "derivedInfo": [
      "jobCategories": [],
      "locations": [
        [
          "latLng": [
            "latitude": "",
            "longitude": ""
          ],
          "locationType": "",
          "postalAddress": [
            "addressLines": [],
            "administrativeArea": "",
            "languageCode": "",
            "locality": "",
            "organization": "",
            "postalCode": "",
            "recipients": [],
            "regionCode": "",
            "revision": 0,
            "sortingCode": "",
            "sublocality": ""
          ],
          "radiusInMiles": ""
        ]
      ]
    ],
    "description": "",
    "employmentTypes": [],
    "incentives": "",
    "jobBenefits": [],
    "jobEndTime": "",
    "jobLevel": "",
    "jobStartTime": "",
    "languageCode": "",
    "name": "",
    "postingCreateTime": "",
    "postingExpireTime": "",
    "postingPublishTime": "",
    "postingRegion": "",
    "postingUpdateTime": "",
    "processingOptions": [
      "disableStreetAddressResolution": false,
      "htmlSanitization": ""
    ],
    "promotionValue": 0,
    "qualifications": "",
    "requisitionId": "",
    "responsibilities": "",
    "title": "",
    "visibility": ""
  ],
  "updateMask": ""
] as [String : Any]

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

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

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

dataTask.resume()
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3p1beta1/:parent/jobs:search");

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  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}");

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

(client/post "{{baseUrl}}/v3p1beta1/:parent/jobs:search" {:content-type :json
                                                                          :form-params {:customRankingInfo {:importanceLevel ""
                                                                                                            :rankingExpression ""}
                                                                                        :disableKeywordMatch false
                                                                                        :diversificationLevel ""
                                                                                        :enableBroadening false
                                                                                        :histogramFacets {:compensationHistogramFacets [{:bucketingOption {:bucketBounds []
                                                                                                                                                           :requiresMinMax false}
                                                                                                                                         :type ""}]
                                                                                                          :customAttributeHistogramFacets [{:key ""
                                                                                                                                            :longValueHistogramBucketingOption {}
                                                                                                                                            :stringValueHistogram false}]
                                                                                                          :simpleHistogramFacets []}
                                                                                        :histogramQueries [{:histogramQuery ""}]
                                                                                        :jobQuery {:commuteFilter {:allowImpreciseAddresses false
                                                                                                                   :commuteMethod ""
                                                                                                                   :departureTime {:hours 0
                                                                                                                                   :minutes 0
                                                                                                                                   :nanos 0
                                                                                                                                   :seconds 0}
                                                                                                                   :roadTraffic ""
                                                                                                                   :startCoordinates {:latitude ""
                                                                                                                                      :longitude ""}
                                                                                                                   :travelDuration ""}
                                                                                                   :companyDisplayNames []
                                                                                                   :companyNames []
                                                                                                   :compensationFilter {:includeJobsWithUnspecifiedCompensationRange false
                                                                                                                        :range {:maxCompensation {:currencyCode ""
                                                                                                                                                  :nanos 0
                                                                                                                                                  :units ""}
                                                                                                                                :minCompensation {}}
                                                                                                                        :type ""
                                                                                                                        :units []}
                                                                                                   :customAttributeFilter ""
                                                                                                   :disableSpellCheck false
                                                                                                   :employmentTypes []
                                                                                                   :excludedJobs []
                                                                                                   :jobCategories []
                                                                                                   :languageCodes []
                                                                                                   :locationFilters [{:address ""
                                                                                                                      :distanceInMiles ""
                                                                                                                      :latLng {}
                                                                                                                      :regionCode ""
                                                                                                                      :telecommutePreference ""}]
                                                                                                   :publishTimeRange {:endTime ""
                                                                                                                      :startTime ""}
                                                                                                   :query ""
                                                                                                   :queryLanguageCode ""}
                                                                                        :jobView ""
                                                                                        :offset 0
                                                                                        :orderBy ""
                                                                                        :pageSize 0
                                                                                        :pageToken ""
                                                                                        :requestMetadata {:deviceInfo {:deviceType ""
                                                                                                                       :id ""}
                                                                                                          :domain ""
                                                                                                          :sessionId ""
                                                                                                          :userId ""}
                                                                                        :requirePreciseResultSize false
                                                                                        :searchMode ""}})
require "http/client"

url = "{{baseUrl}}/v3p1beta1/:parent/jobs:search"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\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}}/v3p1beta1/:parent/jobs:search"),
    Content = new StringContent("{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3p1beta1/:parent/jobs:search");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/:parent/jobs:search"

	payload := strings.NewReader("{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\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/v3p1beta1/:parent/jobs:search HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2151

{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3p1beta1/:parent/jobs:search")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3p1beta1/:parent/jobs:search"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/jobs:search")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3p1beta1/:parent/jobs:search")
  .header("content-type", "application/json")
  .body("{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  customRankingInfo: {
    importanceLevel: '',
    rankingExpression: ''
  },
  disableKeywordMatch: false,
  diversificationLevel: '',
  enableBroadening: false,
  histogramFacets: {
    compensationHistogramFacets: [
      {
        bucketingOption: {
          bucketBounds: [],
          requiresMinMax: false
        },
        type: ''
      }
    ],
    customAttributeHistogramFacets: [
      {
        key: '',
        longValueHistogramBucketingOption: {},
        stringValueHistogram: false
      }
    ],
    simpleHistogramFacets: []
  },
  histogramQueries: [
    {
      histogramQuery: ''
    }
  ],
  jobQuery: {
    commuteFilter: {
      allowImpreciseAddresses: false,
      commuteMethod: '',
      departureTime: {
        hours: 0,
        minutes: 0,
        nanos: 0,
        seconds: 0
      },
      roadTraffic: '',
      startCoordinates: {
        latitude: '',
        longitude: ''
      },
      travelDuration: ''
    },
    companyDisplayNames: [],
    companyNames: [],
    compensationFilter: {
      includeJobsWithUnspecifiedCompensationRange: false,
      range: {
        maxCompensation: {
          currencyCode: '',
          nanos: 0,
          units: ''
        },
        minCompensation: {}
      },
      type: '',
      units: []
    },
    customAttributeFilter: '',
    disableSpellCheck: false,
    employmentTypes: [],
    excludedJobs: [],
    jobCategories: [],
    languageCodes: [],
    locationFilters: [
      {
        address: '',
        distanceInMiles: '',
        latLng: {},
        regionCode: '',
        telecommutePreference: ''
      }
    ],
    publishTimeRange: {
      endTime: '',
      startTime: ''
    },
    query: '',
    queryLanguageCode: ''
  },
  jobView: '',
  offset: 0,
  orderBy: '',
  pageSize: 0,
  pageToken: '',
  requestMetadata: {
    deviceInfo: {
      deviceType: '',
      id: ''
    },
    domain: '',
    sessionId: '',
    userId: ''
  },
  requirePreciseResultSize: false,
  searchMode: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/v3p1beta1/:parent/jobs:search');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs:search',
  headers: {'content-type': 'application/json'},
  data: {
    customRankingInfo: {importanceLevel: '', rankingExpression: ''},
    disableKeywordMatch: false,
    diversificationLevel: '',
    enableBroadening: false,
    histogramFacets: {
      compensationHistogramFacets: [{bucketingOption: {bucketBounds: [], requiresMinMax: false}, type: ''}],
      customAttributeHistogramFacets: [{key: '', longValueHistogramBucketingOption: {}, stringValueHistogram: false}],
      simpleHistogramFacets: []
    },
    histogramQueries: [{histogramQuery: ''}],
    jobQuery: {
      commuteFilter: {
        allowImpreciseAddresses: false,
        commuteMethod: '',
        departureTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
        roadTraffic: '',
        startCoordinates: {latitude: '', longitude: ''},
        travelDuration: ''
      },
      companyDisplayNames: [],
      companyNames: [],
      compensationFilter: {
        includeJobsWithUnspecifiedCompensationRange: false,
        range: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        type: '',
        units: []
      },
      customAttributeFilter: '',
      disableSpellCheck: false,
      employmentTypes: [],
      excludedJobs: [],
      jobCategories: [],
      languageCodes: [],
      locationFilters: [
        {
          address: '',
          distanceInMiles: '',
          latLng: {},
          regionCode: '',
          telecommutePreference: ''
        }
      ],
      publishTimeRange: {endTime: '', startTime: ''},
      query: '',
      queryLanguageCode: ''
    },
    jobView: '',
    offset: 0,
    orderBy: '',
    pageSize: 0,
    pageToken: '',
    requestMetadata: {deviceInfo: {deviceType: '', id: ''}, domain: '', sessionId: '', userId: ''},
    requirePreciseResultSize: false,
    searchMode: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3p1beta1/:parent/jobs:search';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"customRankingInfo":{"importanceLevel":"","rankingExpression":""},"disableKeywordMatch":false,"diversificationLevel":"","enableBroadening":false,"histogramFacets":{"compensationHistogramFacets":[{"bucketingOption":{"bucketBounds":[],"requiresMinMax":false},"type":""}],"customAttributeHistogramFacets":[{"key":"","longValueHistogramBucketingOption":{},"stringValueHistogram":false}],"simpleHistogramFacets":[]},"histogramQueries":[{"histogramQuery":""}],"jobQuery":{"commuteFilter":{"allowImpreciseAddresses":false,"commuteMethod":"","departureTime":{"hours":0,"minutes":0,"nanos":0,"seconds":0},"roadTraffic":"","startCoordinates":{"latitude":"","longitude":""},"travelDuration":""},"companyDisplayNames":[],"companyNames":[],"compensationFilter":{"includeJobsWithUnspecifiedCompensationRange":false,"range":{"maxCompensation":{"currencyCode":"","nanos":0,"units":""},"minCompensation":{}},"type":"","units":[]},"customAttributeFilter":"","disableSpellCheck":false,"employmentTypes":[],"excludedJobs":[],"jobCategories":[],"languageCodes":[],"locationFilters":[{"address":"","distanceInMiles":"","latLng":{},"regionCode":"","telecommutePreference":""}],"publishTimeRange":{"endTime":"","startTime":""},"query":"","queryLanguageCode":""},"jobView":"","offset":0,"orderBy":"","pageSize":0,"pageToken":"","requestMetadata":{"deviceInfo":{"deviceType":"","id":""},"domain":"","sessionId":"","userId":""},"requirePreciseResultSize":false,"searchMode":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs:search',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "customRankingInfo": {\n    "importanceLevel": "",\n    "rankingExpression": ""\n  },\n  "disableKeywordMatch": false,\n  "diversificationLevel": "",\n  "enableBroadening": false,\n  "histogramFacets": {\n    "compensationHistogramFacets": [\n      {\n        "bucketingOption": {\n          "bucketBounds": [],\n          "requiresMinMax": false\n        },\n        "type": ""\n      }\n    ],\n    "customAttributeHistogramFacets": [\n      {\n        "key": "",\n        "longValueHistogramBucketingOption": {},\n        "stringValueHistogram": false\n      }\n    ],\n    "simpleHistogramFacets": []\n  },\n  "histogramQueries": [\n    {\n      "histogramQuery": ""\n    }\n  ],\n  "jobQuery": {\n    "commuteFilter": {\n      "allowImpreciseAddresses": false,\n      "commuteMethod": "",\n      "departureTime": {\n        "hours": 0,\n        "minutes": 0,\n        "nanos": 0,\n        "seconds": 0\n      },\n      "roadTraffic": "",\n      "startCoordinates": {\n        "latitude": "",\n        "longitude": ""\n      },\n      "travelDuration": ""\n    },\n    "companyDisplayNames": [],\n    "companyNames": [],\n    "compensationFilter": {\n      "includeJobsWithUnspecifiedCompensationRange": false,\n      "range": {\n        "maxCompensation": {\n          "currencyCode": "",\n          "nanos": 0,\n          "units": ""\n        },\n        "minCompensation": {}\n      },\n      "type": "",\n      "units": []\n    },\n    "customAttributeFilter": "",\n    "disableSpellCheck": false,\n    "employmentTypes": [],\n    "excludedJobs": [],\n    "jobCategories": [],\n    "languageCodes": [],\n    "locationFilters": [\n      {\n        "address": "",\n        "distanceInMiles": "",\n        "latLng": {},\n        "regionCode": "",\n        "telecommutePreference": ""\n      }\n    ],\n    "publishTimeRange": {\n      "endTime": "",\n      "startTime": ""\n    },\n    "query": "",\n    "queryLanguageCode": ""\n  },\n  "jobView": "",\n  "offset": 0,\n  "orderBy": "",\n  "pageSize": 0,\n  "pageToken": "",\n  "requestMetadata": {\n    "deviceInfo": {\n      "deviceType": "",\n      "id": ""\n    },\n    "domain": "",\n    "sessionId": "",\n    "userId": ""\n  },\n  "requirePreciseResultSize": false,\n  "searchMode": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/jobs:search")
  .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/v3p1beta1/:parent/jobs:search',
  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({
  customRankingInfo: {importanceLevel: '', rankingExpression: ''},
  disableKeywordMatch: false,
  diversificationLevel: '',
  enableBroadening: false,
  histogramFacets: {
    compensationHistogramFacets: [{bucketingOption: {bucketBounds: [], requiresMinMax: false}, type: ''}],
    customAttributeHistogramFacets: [{key: '', longValueHistogramBucketingOption: {}, stringValueHistogram: false}],
    simpleHistogramFacets: []
  },
  histogramQueries: [{histogramQuery: ''}],
  jobQuery: {
    commuteFilter: {
      allowImpreciseAddresses: false,
      commuteMethod: '',
      departureTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
      roadTraffic: '',
      startCoordinates: {latitude: '', longitude: ''},
      travelDuration: ''
    },
    companyDisplayNames: [],
    companyNames: [],
    compensationFilter: {
      includeJobsWithUnspecifiedCompensationRange: false,
      range: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
      type: '',
      units: []
    },
    customAttributeFilter: '',
    disableSpellCheck: false,
    employmentTypes: [],
    excludedJobs: [],
    jobCategories: [],
    languageCodes: [],
    locationFilters: [
      {
        address: '',
        distanceInMiles: '',
        latLng: {},
        regionCode: '',
        telecommutePreference: ''
      }
    ],
    publishTimeRange: {endTime: '', startTime: ''},
    query: '',
    queryLanguageCode: ''
  },
  jobView: '',
  offset: 0,
  orderBy: '',
  pageSize: 0,
  pageToken: '',
  requestMetadata: {deviceInfo: {deviceType: '', id: ''}, domain: '', sessionId: '', userId: ''},
  requirePreciseResultSize: false,
  searchMode: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs:search',
  headers: {'content-type': 'application/json'},
  body: {
    customRankingInfo: {importanceLevel: '', rankingExpression: ''},
    disableKeywordMatch: false,
    diversificationLevel: '',
    enableBroadening: false,
    histogramFacets: {
      compensationHistogramFacets: [{bucketingOption: {bucketBounds: [], requiresMinMax: false}, type: ''}],
      customAttributeHistogramFacets: [{key: '', longValueHistogramBucketingOption: {}, stringValueHistogram: false}],
      simpleHistogramFacets: []
    },
    histogramQueries: [{histogramQuery: ''}],
    jobQuery: {
      commuteFilter: {
        allowImpreciseAddresses: false,
        commuteMethod: '',
        departureTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
        roadTraffic: '',
        startCoordinates: {latitude: '', longitude: ''},
        travelDuration: ''
      },
      companyDisplayNames: [],
      companyNames: [],
      compensationFilter: {
        includeJobsWithUnspecifiedCompensationRange: false,
        range: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        type: '',
        units: []
      },
      customAttributeFilter: '',
      disableSpellCheck: false,
      employmentTypes: [],
      excludedJobs: [],
      jobCategories: [],
      languageCodes: [],
      locationFilters: [
        {
          address: '',
          distanceInMiles: '',
          latLng: {},
          regionCode: '',
          telecommutePreference: ''
        }
      ],
      publishTimeRange: {endTime: '', startTime: ''},
      query: '',
      queryLanguageCode: ''
    },
    jobView: '',
    offset: 0,
    orderBy: '',
    pageSize: 0,
    pageToken: '',
    requestMetadata: {deviceInfo: {deviceType: '', id: ''}, domain: '', sessionId: '', userId: ''},
    requirePreciseResultSize: false,
    searchMode: ''
  },
  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}}/v3p1beta1/:parent/jobs:search');

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

req.type('json');
req.send({
  customRankingInfo: {
    importanceLevel: '',
    rankingExpression: ''
  },
  disableKeywordMatch: false,
  diversificationLevel: '',
  enableBroadening: false,
  histogramFacets: {
    compensationHistogramFacets: [
      {
        bucketingOption: {
          bucketBounds: [],
          requiresMinMax: false
        },
        type: ''
      }
    ],
    customAttributeHistogramFacets: [
      {
        key: '',
        longValueHistogramBucketingOption: {},
        stringValueHistogram: false
      }
    ],
    simpleHistogramFacets: []
  },
  histogramQueries: [
    {
      histogramQuery: ''
    }
  ],
  jobQuery: {
    commuteFilter: {
      allowImpreciseAddresses: false,
      commuteMethod: '',
      departureTime: {
        hours: 0,
        minutes: 0,
        nanos: 0,
        seconds: 0
      },
      roadTraffic: '',
      startCoordinates: {
        latitude: '',
        longitude: ''
      },
      travelDuration: ''
    },
    companyDisplayNames: [],
    companyNames: [],
    compensationFilter: {
      includeJobsWithUnspecifiedCompensationRange: false,
      range: {
        maxCompensation: {
          currencyCode: '',
          nanos: 0,
          units: ''
        },
        minCompensation: {}
      },
      type: '',
      units: []
    },
    customAttributeFilter: '',
    disableSpellCheck: false,
    employmentTypes: [],
    excludedJobs: [],
    jobCategories: [],
    languageCodes: [],
    locationFilters: [
      {
        address: '',
        distanceInMiles: '',
        latLng: {},
        regionCode: '',
        telecommutePreference: ''
      }
    ],
    publishTimeRange: {
      endTime: '',
      startTime: ''
    },
    query: '',
    queryLanguageCode: ''
  },
  jobView: '',
  offset: 0,
  orderBy: '',
  pageSize: 0,
  pageToken: '',
  requestMetadata: {
    deviceInfo: {
      deviceType: '',
      id: ''
    },
    domain: '',
    sessionId: '',
    userId: ''
  },
  requirePreciseResultSize: false,
  searchMode: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs:search',
  headers: {'content-type': 'application/json'},
  data: {
    customRankingInfo: {importanceLevel: '', rankingExpression: ''},
    disableKeywordMatch: false,
    diversificationLevel: '',
    enableBroadening: false,
    histogramFacets: {
      compensationHistogramFacets: [{bucketingOption: {bucketBounds: [], requiresMinMax: false}, type: ''}],
      customAttributeHistogramFacets: [{key: '', longValueHistogramBucketingOption: {}, stringValueHistogram: false}],
      simpleHistogramFacets: []
    },
    histogramQueries: [{histogramQuery: ''}],
    jobQuery: {
      commuteFilter: {
        allowImpreciseAddresses: false,
        commuteMethod: '',
        departureTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
        roadTraffic: '',
        startCoordinates: {latitude: '', longitude: ''},
        travelDuration: ''
      },
      companyDisplayNames: [],
      companyNames: [],
      compensationFilter: {
        includeJobsWithUnspecifiedCompensationRange: false,
        range: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        type: '',
        units: []
      },
      customAttributeFilter: '',
      disableSpellCheck: false,
      employmentTypes: [],
      excludedJobs: [],
      jobCategories: [],
      languageCodes: [],
      locationFilters: [
        {
          address: '',
          distanceInMiles: '',
          latLng: {},
          regionCode: '',
          telecommutePreference: ''
        }
      ],
      publishTimeRange: {endTime: '', startTime: ''},
      query: '',
      queryLanguageCode: ''
    },
    jobView: '',
    offset: 0,
    orderBy: '',
    pageSize: 0,
    pageToken: '',
    requestMetadata: {deviceInfo: {deviceType: '', id: ''}, domain: '', sessionId: '', userId: ''},
    requirePreciseResultSize: false,
    searchMode: ''
  }
};

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

const url = '{{baseUrl}}/v3p1beta1/:parent/jobs:search';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"customRankingInfo":{"importanceLevel":"","rankingExpression":""},"disableKeywordMatch":false,"diversificationLevel":"","enableBroadening":false,"histogramFacets":{"compensationHistogramFacets":[{"bucketingOption":{"bucketBounds":[],"requiresMinMax":false},"type":""}],"customAttributeHistogramFacets":[{"key":"","longValueHistogramBucketingOption":{},"stringValueHistogram":false}],"simpleHistogramFacets":[]},"histogramQueries":[{"histogramQuery":""}],"jobQuery":{"commuteFilter":{"allowImpreciseAddresses":false,"commuteMethod":"","departureTime":{"hours":0,"minutes":0,"nanos":0,"seconds":0},"roadTraffic":"","startCoordinates":{"latitude":"","longitude":""},"travelDuration":""},"companyDisplayNames":[],"companyNames":[],"compensationFilter":{"includeJobsWithUnspecifiedCompensationRange":false,"range":{"maxCompensation":{"currencyCode":"","nanos":0,"units":""},"minCompensation":{}},"type":"","units":[]},"customAttributeFilter":"","disableSpellCheck":false,"employmentTypes":[],"excludedJobs":[],"jobCategories":[],"languageCodes":[],"locationFilters":[{"address":"","distanceInMiles":"","latLng":{},"regionCode":"","telecommutePreference":""}],"publishTimeRange":{"endTime":"","startTime":""},"query":"","queryLanguageCode":""},"jobView":"","offset":0,"orderBy":"","pageSize":0,"pageToken":"","requestMetadata":{"deviceInfo":{"deviceType":"","id":""},"domain":"","sessionId":"","userId":""},"requirePreciseResultSize":false,"searchMode":""}'
};

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 = @{ @"customRankingInfo": @{ @"importanceLevel": @"", @"rankingExpression": @"" },
                              @"disableKeywordMatch": @NO,
                              @"diversificationLevel": @"",
                              @"enableBroadening": @NO,
                              @"histogramFacets": @{ @"compensationHistogramFacets": @[ @{ @"bucketingOption": @{ @"bucketBounds": @[  ], @"requiresMinMax": @NO }, @"type": @"" } ], @"customAttributeHistogramFacets": @[ @{ @"key": @"", @"longValueHistogramBucketingOption": @{  }, @"stringValueHistogram": @NO } ], @"simpleHistogramFacets": @[  ] },
                              @"histogramQueries": @[ @{ @"histogramQuery": @"" } ],
                              @"jobQuery": @{ @"commuteFilter": @{ @"allowImpreciseAddresses": @NO, @"commuteMethod": @"", @"departureTime": @{ @"hours": @0, @"minutes": @0, @"nanos": @0, @"seconds": @0 }, @"roadTraffic": @"", @"startCoordinates": @{ @"latitude": @"", @"longitude": @"" }, @"travelDuration": @"" }, @"companyDisplayNames": @[  ], @"companyNames": @[  ], @"compensationFilter": @{ @"includeJobsWithUnspecifiedCompensationRange": @NO, @"range": @{ @"maxCompensation": @{ @"currencyCode": @"", @"nanos": @0, @"units": @"" }, @"minCompensation": @{  } }, @"type": @"", @"units": @[  ] }, @"customAttributeFilter": @"", @"disableSpellCheck": @NO, @"employmentTypes": @[  ], @"excludedJobs": @[  ], @"jobCategories": @[  ], @"languageCodes": @[  ], @"locationFilters": @[ @{ @"address": @"", @"distanceInMiles": @"", @"latLng": @{  }, @"regionCode": @"", @"telecommutePreference": @"" } ], @"publishTimeRange": @{ @"endTime": @"", @"startTime": @"" }, @"query": @"", @"queryLanguageCode": @"" },
                              @"jobView": @"",
                              @"offset": @0,
                              @"orderBy": @"",
                              @"pageSize": @0,
                              @"pageToken": @"",
                              @"requestMetadata": @{ @"deviceInfo": @{ @"deviceType": @"", @"id": @"" }, @"domain": @"", @"sessionId": @"", @"userId": @"" },
                              @"requirePreciseResultSize": @NO,
                              @"searchMode": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3p1beta1/:parent/jobs:search"]
                                                       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}}/v3p1beta1/:parent/jobs:search" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3p1beta1/:parent/jobs:search",
  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([
    'customRankingInfo' => [
        'importanceLevel' => '',
        'rankingExpression' => ''
    ],
    'disableKeywordMatch' => null,
    'diversificationLevel' => '',
    'enableBroadening' => null,
    'histogramFacets' => [
        'compensationHistogramFacets' => [
                [
                                'bucketingOption' => [
                                                                'bucketBounds' => [
                                                                                                                                
                                                                ],
                                                                'requiresMinMax' => null
                                ],
                                'type' => ''
                ]
        ],
        'customAttributeHistogramFacets' => [
                [
                                'key' => '',
                                'longValueHistogramBucketingOption' => [
                                                                
                                ],
                                'stringValueHistogram' => null
                ]
        ],
        'simpleHistogramFacets' => [
                
        ]
    ],
    'histogramQueries' => [
        [
                'histogramQuery' => ''
        ]
    ],
    'jobQuery' => [
        'commuteFilter' => [
                'allowImpreciseAddresses' => null,
                'commuteMethod' => '',
                'departureTime' => [
                                'hours' => 0,
                                'minutes' => 0,
                                'nanos' => 0,
                                'seconds' => 0
                ],
                'roadTraffic' => '',
                'startCoordinates' => [
                                'latitude' => '',
                                'longitude' => ''
                ],
                'travelDuration' => ''
        ],
        'companyDisplayNames' => [
                
        ],
        'companyNames' => [
                
        ],
        'compensationFilter' => [
                'includeJobsWithUnspecifiedCompensationRange' => null,
                'range' => [
                                'maxCompensation' => [
                                                                'currencyCode' => '',
                                                                'nanos' => 0,
                                                                'units' => ''
                                ],
                                'minCompensation' => [
                                                                
                                ]
                ],
                'type' => '',
                'units' => [
                                
                ]
        ],
        'customAttributeFilter' => '',
        'disableSpellCheck' => null,
        'employmentTypes' => [
                
        ],
        'excludedJobs' => [
                
        ],
        'jobCategories' => [
                
        ],
        'languageCodes' => [
                
        ],
        'locationFilters' => [
                [
                                'address' => '',
                                'distanceInMiles' => '',
                                'latLng' => [
                                                                
                                ],
                                'regionCode' => '',
                                'telecommutePreference' => ''
                ]
        ],
        'publishTimeRange' => [
                'endTime' => '',
                'startTime' => ''
        ],
        'query' => '',
        'queryLanguageCode' => ''
    ],
    'jobView' => '',
    'offset' => 0,
    'orderBy' => '',
    'pageSize' => 0,
    'pageToken' => '',
    'requestMetadata' => [
        'deviceInfo' => [
                'deviceType' => '',
                'id' => ''
        ],
        'domain' => '',
        'sessionId' => '',
        'userId' => ''
    ],
    'requirePreciseResultSize' => null,
    'searchMode' => ''
  ]),
  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}}/v3p1beta1/:parent/jobs:search', [
  'body' => '{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3p1beta1/:parent/jobs:search');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'customRankingInfo' => [
    'importanceLevel' => '',
    'rankingExpression' => ''
  ],
  'disableKeywordMatch' => null,
  'diversificationLevel' => '',
  'enableBroadening' => null,
  'histogramFacets' => [
    'compensationHistogramFacets' => [
        [
                'bucketingOption' => [
                                'bucketBounds' => [
                                                                
                                ],
                                'requiresMinMax' => null
                ],
                'type' => ''
        ]
    ],
    'customAttributeHistogramFacets' => [
        [
                'key' => '',
                'longValueHistogramBucketingOption' => [
                                
                ],
                'stringValueHistogram' => null
        ]
    ],
    'simpleHistogramFacets' => [
        
    ]
  ],
  'histogramQueries' => [
    [
        'histogramQuery' => ''
    ]
  ],
  'jobQuery' => [
    'commuteFilter' => [
        'allowImpreciseAddresses' => null,
        'commuteMethod' => '',
        'departureTime' => [
                'hours' => 0,
                'minutes' => 0,
                'nanos' => 0,
                'seconds' => 0
        ],
        'roadTraffic' => '',
        'startCoordinates' => [
                'latitude' => '',
                'longitude' => ''
        ],
        'travelDuration' => ''
    ],
    'companyDisplayNames' => [
        
    ],
    'companyNames' => [
        
    ],
    'compensationFilter' => [
        'includeJobsWithUnspecifiedCompensationRange' => null,
        'range' => [
                'maxCompensation' => [
                                'currencyCode' => '',
                                'nanos' => 0,
                                'units' => ''
                ],
                'minCompensation' => [
                                
                ]
        ],
        'type' => '',
        'units' => [
                
        ]
    ],
    'customAttributeFilter' => '',
    'disableSpellCheck' => null,
    'employmentTypes' => [
        
    ],
    'excludedJobs' => [
        
    ],
    'jobCategories' => [
        
    ],
    'languageCodes' => [
        
    ],
    'locationFilters' => [
        [
                'address' => '',
                'distanceInMiles' => '',
                'latLng' => [
                                
                ],
                'regionCode' => '',
                'telecommutePreference' => ''
        ]
    ],
    'publishTimeRange' => [
        'endTime' => '',
        'startTime' => ''
    ],
    'query' => '',
    'queryLanguageCode' => ''
  ],
  'jobView' => '',
  'offset' => 0,
  'orderBy' => '',
  'pageSize' => 0,
  'pageToken' => '',
  'requestMetadata' => [
    'deviceInfo' => [
        'deviceType' => '',
        'id' => ''
    ],
    'domain' => '',
    'sessionId' => '',
    'userId' => ''
  ],
  'requirePreciseResultSize' => null,
  'searchMode' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'customRankingInfo' => [
    'importanceLevel' => '',
    'rankingExpression' => ''
  ],
  'disableKeywordMatch' => null,
  'diversificationLevel' => '',
  'enableBroadening' => null,
  'histogramFacets' => [
    'compensationHistogramFacets' => [
        [
                'bucketingOption' => [
                                'bucketBounds' => [
                                                                
                                ],
                                'requiresMinMax' => null
                ],
                'type' => ''
        ]
    ],
    'customAttributeHistogramFacets' => [
        [
                'key' => '',
                'longValueHistogramBucketingOption' => [
                                
                ],
                'stringValueHistogram' => null
        ]
    ],
    'simpleHistogramFacets' => [
        
    ]
  ],
  'histogramQueries' => [
    [
        'histogramQuery' => ''
    ]
  ],
  'jobQuery' => [
    'commuteFilter' => [
        'allowImpreciseAddresses' => null,
        'commuteMethod' => '',
        'departureTime' => [
                'hours' => 0,
                'minutes' => 0,
                'nanos' => 0,
                'seconds' => 0
        ],
        'roadTraffic' => '',
        'startCoordinates' => [
                'latitude' => '',
                'longitude' => ''
        ],
        'travelDuration' => ''
    ],
    'companyDisplayNames' => [
        
    ],
    'companyNames' => [
        
    ],
    'compensationFilter' => [
        'includeJobsWithUnspecifiedCompensationRange' => null,
        'range' => [
                'maxCompensation' => [
                                'currencyCode' => '',
                                'nanos' => 0,
                                'units' => ''
                ],
                'minCompensation' => [
                                
                ]
        ],
        'type' => '',
        'units' => [
                
        ]
    ],
    'customAttributeFilter' => '',
    'disableSpellCheck' => null,
    'employmentTypes' => [
        
    ],
    'excludedJobs' => [
        
    ],
    'jobCategories' => [
        
    ],
    'languageCodes' => [
        
    ],
    'locationFilters' => [
        [
                'address' => '',
                'distanceInMiles' => '',
                'latLng' => [
                                
                ],
                'regionCode' => '',
                'telecommutePreference' => ''
        ]
    ],
    'publishTimeRange' => [
        'endTime' => '',
        'startTime' => ''
    ],
    'query' => '',
    'queryLanguageCode' => ''
  ],
  'jobView' => '',
  'offset' => 0,
  'orderBy' => '',
  'pageSize' => 0,
  'pageToken' => '',
  'requestMetadata' => [
    'deviceInfo' => [
        'deviceType' => '',
        'id' => ''
    ],
    'domain' => '',
    'sessionId' => '',
    'userId' => ''
  ],
  'requirePreciseResultSize' => null,
  'searchMode' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3p1beta1/:parent/jobs:search');
$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}}/v3p1beta1/:parent/jobs:search' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3p1beta1/:parent/jobs:search' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}'
import http.client

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

payload = "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v3p1beta1/:parent/jobs:search", payload, headers)

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

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

url = "{{baseUrl}}/v3p1beta1/:parent/jobs:search"

payload = {
    "customRankingInfo": {
        "importanceLevel": "",
        "rankingExpression": ""
    },
    "disableKeywordMatch": False,
    "diversificationLevel": "",
    "enableBroadening": False,
    "histogramFacets": {
        "compensationHistogramFacets": [
            {
                "bucketingOption": {
                    "bucketBounds": [],
                    "requiresMinMax": False
                },
                "type": ""
            }
        ],
        "customAttributeHistogramFacets": [
            {
                "key": "",
                "longValueHistogramBucketingOption": {},
                "stringValueHistogram": False
            }
        ],
        "simpleHistogramFacets": []
    },
    "histogramQueries": [{ "histogramQuery": "" }],
    "jobQuery": {
        "commuteFilter": {
            "allowImpreciseAddresses": False,
            "commuteMethod": "",
            "departureTime": {
                "hours": 0,
                "minutes": 0,
                "nanos": 0,
                "seconds": 0
            },
            "roadTraffic": "",
            "startCoordinates": {
                "latitude": "",
                "longitude": ""
            },
            "travelDuration": ""
        },
        "companyDisplayNames": [],
        "companyNames": [],
        "compensationFilter": {
            "includeJobsWithUnspecifiedCompensationRange": False,
            "range": {
                "maxCompensation": {
                    "currencyCode": "",
                    "nanos": 0,
                    "units": ""
                },
                "minCompensation": {}
            },
            "type": "",
            "units": []
        },
        "customAttributeFilter": "",
        "disableSpellCheck": False,
        "employmentTypes": [],
        "excludedJobs": [],
        "jobCategories": [],
        "languageCodes": [],
        "locationFilters": [
            {
                "address": "",
                "distanceInMiles": "",
                "latLng": {},
                "regionCode": "",
                "telecommutePreference": ""
            }
        ],
        "publishTimeRange": {
            "endTime": "",
            "startTime": ""
        },
        "query": "",
        "queryLanguageCode": ""
    },
    "jobView": "",
    "offset": 0,
    "orderBy": "",
    "pageSize": 0,
    "pageToken": "",
    "requestMetadata": {
        "deviceInfo": {
            "deviceType": "",
            "id": ""
        },
        "domain": "",
        "sessionId": "",
        "userId": ""
    },
    "requirePreciseResultSize": False,
    "searchMode": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3p1beta1/:parent/jobs:search"

payload <- "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\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}}/v3p1beta1/:parent/jobs:search")

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  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}"

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/v3p1beta1/:parent/jobs:search') do |req|
  req.body = "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}"
end

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

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

    let payload = json!({
        "customRankingInfo": json!({
            "importanceLevel": "",
            "rankingExpression": ""
        }),
        "disableKeywordMatch": false,
        "diversificationLevel": "",
        "enableBroadening": false,
        "histogramFacets": json!({
            "compensationHistogramFacets": (
                json!({
                    "bucketingOption": json!({
                        "bucketBounds": (),
                        "requiresMinMax": false
                    }),
                    "type": ""
                })
            ),
            "customAttributeHistogramFacets": (
                json!({
                    "key": "",
                    "longValueHistogramBucketingOption": json!({}),
                    "stringValueHistogram": false
                })
            ),
            "simpleHistogramFacets": ()
        }),
        "histogramQueries": (json!({"histogramQuery": ""})),
        "jobQuery": json!({
            "commuteFilter": json!({
                "allowImpreciseAddresses": false,
                "commuteMethod": "",
                "departureTime": json!({
                    "hours": 0,
                    "minutes": 0,
                    "nanos": 0,
                    "seconds": 0
                }),
                "roadTraffic": "",
                "startCoordinates": json!({
                    "latitude": "",
                    "longitude": ""
                }),
                "travelDuration": ""
            }),
            "companyDisplayNames": (),
            "companyNames": (),
            "compensationFilter": json!({
                "includeJobsWithUnspecifiedCompensationRange": false,
                "range": json!({
                    "maxCompensation": json!({
                        "currencyCode": "",
                        "nanos": 0,
                        "units": ""
                    }),
                    "minCompensation": json!({})
                }),
                "type": "",
                "units": ()
            }),
            "customAttributeFilter": "",
            "disableSpellCheck": false,
            "employmentTypes": (),
            "excludedJobs": (),
            "jobCategories": (),
            "languageCodes": (),
            "locationFilters": (
                json!({
                    "address": "",
                    "distanceInMiles": "",
                    "latLng": json!({}),
                    "regionCode": "",
                    "telecommutePreference": ""
                })
            ),
            "publishTimeRange": json!({
                "endTime": "",
                "startTime": ""
            }),
            "query": "",
            "queryLanguageCode": ""
        }),
        "jobView": "",
        "offset": 0,
        "orderBy": "",
        "pageSize": 0,
        "pageToken": "",
        "requestMetadata": json!({
            "deviceInfo": json!({
                "deviceType": "",
                "id": ""
            }),
            "domain": "",
            "sessionId": "",
            "userId": ""
        }),
        "requirePreciseResultSize": false,
        "searchMode": ""
    });

    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}}/v3p1beta1/:parent/jobs:search \
  --header 'content-type: application/json' \
  --data '{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}'
echo '{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}' |  \
  http POST {{baseUrl}}/v3p1beta1/:parent/jobs:search \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "customRankingInfo": {\n    "importanceLevel": "",\n    "rankingExpression": ""\n  },\n  "disableKeywordMatch": false,\n  "diversificationLevel": "",\n  "enableBroadening": false,\n  "histogramFacets": {\n    "compensationHistogramFacets": [\n      {\n        "bucketingOption": {\n          "bucketBounds": [],\n          "requiresMinMax": false\n        },\n        "type": ""\n      }\n    ],\n    "customAttributeHistogramFacets": [\n      {\n        "key": "",\n        "longValueHistogramBucketingOption": {},\n        "stringValueHistogram": false\n      }\n    ],\n    "simpleHistogramFacets": []\n  },\n  "histogramQueries": [\n    {\n      "histogramQuery": ""\n    }\n  ],\n  "jobQuery": {\n    "commuteFilter": {\n      "allowImpreciseAddresses": false,\n      "commuteMethod": "",\n      "departureTime": {\n        "hours": 0,\n        "minutes": 0,\n        "nanos": 0,\n        "seconds": 0\n      },\n      "roadTraffic": "",\n      "startCoordinates": {\n        "latitude": "",\n        "longitude": ""\n      },\n      "travelDuration": ""\n    },\n    "companyDisplayNames": [],\n    "companyNames": [],\n    "compensationFilter": {\n      "includeJobsWithUnspecifiedCompensationRange": false,\n      "range": {\n        "maxCompensation": {\n          "currencyCode": "",\n          "nanos": 0,\n          "units": ""\n        },\n        "minCompensation": {}\n      },\n      "type": "",\n      "units": []\n    },\n    "customAttributeFilter": "",\n    "disableSpellCheck": false,\n    "employmentTypes": [],\n    "excludedJobs": [],\n    "jobCategories": [],\n    "languageCodes": [],\n    "locationFilters": [\n      {\n        "address": "",\n        "distanceInMiles": "",\n        "latLng": {},\n        "regionCode": "",\n        "telecommutePreference": ""\n      }\n    ],\n    "publishTimeRange": {\n      "endTime": "",\n      "startTime": ""\n    },\n    "query": "",\n    "queryLanguageCode": ""\n  },\n  "jobView": "",\n  "offset": 0,\n  "orderBy": "",\n  "pageSize": 0,\n  "pageToken": "",\n  "requestMetadata": {\n    "deviceInfo": {\n      "deviceType": "",\n      "id": ""\n    },\n    "domain": "",\n    "sessionId": "",\n    "userId": ""\n  },\n  "requirePreciseResultSize": false,\n  "searchMode": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:parent/jobs:search
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "customRankingInfo": [
    "importanceLevel": "",
    "rankingExpression": ""
  ],
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": [
    "compensationHistogramFacets": [
      [
        "bucketingOption": [
          "bucketBounds": [],
          "requiresMinMax": false
        ],
        "type": ""
      ]
    ],
    "customAttributeHistogramFacets": [
      [
        "key": "",
        "longValueHistogramBucketingOption": [],
        "stringValueHistogram": false
      ]
    ],
    "simpleHistogramFacets": []
  ],
  "histogramQueries": [["histogramQuery": ""]],
  "jobQuery": [
    "commuteFilter": [
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": [
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      ],
      "roadTraffic": "",
      "startCoordinates": [
        "latitude": "",
        "longitude": ""
      ],
      "travelDuration": ""
    ],
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": [
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": [
        "maxCompensation": [
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        ],
        "minCompensation": []
      ],
      "type": "",
      "units": []
    ],
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      [
        "address": "",
        "distanceInMiles": "",
        "latLng": [],
        "regionCode": "",
        "telecommutePreference": ""
      ]
    ],
    "publishTimeRange": [
      "endTime": "",
      "startTime": ""
    ],
    "query": "",
    "queryLanguageCode": ""
  ],
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": [
    "deviceInfo": [
      "deviceType": "",
      "id": ""
    ],
    "domain": "",
    "sessionId": "",
    "userId": ""
  ],
  "requirePreciseResultSize": false,
  "searchMode": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3p1beta1/:parent/jobs:search")! 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 jobs.projects.jobs.searchForAlert
{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert
QUERY PARAMS

parent
BODY json

{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert");

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  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}");

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

(client/post "{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert" {:content-type :json
                                                                                  :form-params {:customRankingInfo {:importanceLevel ""
                                                                                                                    :rankingExpression ""}
                                                                                                :disableKeywordMatch false
                                                                                                :diversificationLevel ""
                                                                                                :enableBroadening false
                                                                                                :histogramFacets {:compensationHistogramFacets [{:bucketingOption {:bucketBounds []
                                                                                                                                                                   :requiresMinMax false}
                                                                                                                                                 :type ""}]
                                                                                                                  :customAttributeHistogramFacets [{:key ""
                                                                                                                                                    :longValueHistogramBucketingOption {}
                                                                                                                                                    :stringValueHistogram false}]
                                                                                                                  :simpleHistogramFacets []}
                                                                                                :histogramQueries [{:histogramQuery ""}]
                                                                                                :jobQuery {:commuteFilter {:allowImpreciseAddresses false
                                                                                                                           :commuteMethod ""
                                                                                                                           :departureTime {:hours 0
                                                                                                                                           :minutes 0
                                                                                                                                           :nanos 0
                                                                                                                                           :seconds 0}
                                                                                                                           :roadTraffic ""
                                                                                                                           :startCoordinates {:latitude ""
                                                                                                                                              :longitude ""}
                                                                                                                           :travelDuration ""}
                                                                                                           :companyDisplayNames []
                                                                                                           :companyNames []
                                                                                                           :compensationFilter {:includeJobsWithUnspecifiedCompensationRange false
                                                                                                                                :range {:maxCompensation {:currencyCode ""
                                                                                                                                                          :nanos 0
                                                                                                                                                          :units ""}
                                                                                                                                        :minCompensation {}}
                                                                                                                                :type ""
                                                                                                                                :units []}
                                                                                                           :customAttributeFilter ""
                                                                                                           :disableSpellCheck false
                                                                                                           :employmentTypes []
                                                                                                           :excludedJobs []
                                                                                                           :jobCategories []
                                                                                                           :languageCodes []
                                                                                                           :locationFilters [{:address ""
                                                                                                                              :distanceInMiles ""
                                                                                                                              :latLng {}
                                                                                                                              :regionCode ""
                                                                                                                              :telecommutePreference ""}]
                                                                                                           :publishTimeRange {:endTime ""
                                                                                                                              :startTime ""}
                                                                                                           :query ""
                                                                                                           :queryLanguageCode ""}
                                                                                                :jobView ""
                                                                                                :offset 0
                                                                                                :orderBy ""
                                                                                                :pageSize 0
                                                                                                :pageToken ""
                                                                                                :requestMetadata {:deviceInfo {:deviceType ""
                                                                                                                               :id ""}
                                                                                                                  :domain ""
                                                                                                                  :sessionId ""
                                                                                                                  :userId ""}
                                                                                                :requirePreciseResultSize false
                                                                                                :searchMode ""}})
require "http/client"

url = "{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\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}}/v3p1beta1/:parent/jobs:searchForAlert"),
    Content = new StringContent("{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert"

	payload := strings.NewReader("{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\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/v3p1beta1/:parent/jobs:searchForAlert HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2151

{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert")
  .header("content-type", "application/json")
  .body("{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  customRankingInfo: {
    importanceLevel: '',
    rankingExpression: ''
  },
  disableKeywordMatch: false,
  diversificationLevel: '',
  enableBroadening: false,
  histogramFacets: {
    compensationHistogramFacets: [
      {
        bucketingOption: {
          bucketBounds: [],
          requiresMinMax: false
        },
        type: ''
      }
    ],
    customAttributeHistogramFacets: [
      {
        key: '',
        longValueHistogramBucketingOption: {},
        stringValueHistogram: false
      }
    ],
    simpleHistogramFacets: []
  },
  histogramQueries: [
    {
      histogramQuery: ''
    }
  ],
  jobQuery: {
    commuteFilter: {
      allowImpreciseAddresses: false,
      commuteMethod: '',
      departureTime: {
        hours: 0,
        minutes: 0,
        nanos: 0,
        seconds: 0
      },
      roadTraffic: '',
      startCoordinates: {
        latitude: '',
        longitude: ''
      },
      travelDuration: ''
    },
    companyDisplayNames: [],
    companyNames: [],
    compensationFilter: {
      includeJobsWithUnspecifiedCompensationRange: false,
      range: {
        maxCompensation: {
          currencyCode: '',
          nanos: 0,
          units: ''
        },
        minCompensation: {}
      },
      type: '',
      units: []
    },
    customAttributeFilter: '',
    disableSpellCheck: false,
    employmentTypes: [],
    excludedJobs: [],
    jobCategories: [],
    languageCodes: [],
    locationFilters: [
      {
        address: '',
        distanceInMiles: '',
        latLng: {},
        regionCode: '',
        telecommutePreference: ''
      }
    ],
    publishTimeRange: {
      endTime: '',
      startTime: ''
    },
    query: '',
    queryLanguageCode: ''
  },
  jobView: '',
  offset: 0,
  orderBy: '',
  pageSize: 0,
  pageToken: '',
  requestMetadata: {
    deviceInfo: {
      deviceType: '',
      id: ''
    },
    domain: '',
    sessionId: '',
    userId: ''
  },
  requirePreciseResultSize: false,
  searchMode: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert',
  headers: {'content-type': 'application/json'},
  data: {
    customRankingInfo: {importanceLevel: '', rankingExpression: ''},
    disableKeywordMatch: false,
    diversificationLevel: '',
    enableBroadening: false,
    histogramFacets: {
      compensationHistogramFacets: [{bucketingOption: {bucketBounds: [], requiresMinMax: false}, type: ''}],
      customAttributeHistogramFacets: [{key: '', longValueHistogramBucketingOption: {}, stringValueHistogram: false}],
      simpleHistogramFacets: []
    },
    histogramQueries: [{histogramQuery: ''}],
    jobQuery: {
      commuteFilter: {
        allowImpreciseAddresses: false,
        commuteMethod: '',
        departureTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
        roadTraffic: '',
        startCoordinates: {latitude: '', longitude: ''},
        travelDuration: ''
      },
      companyDisplayNames: [],
      companyNames: [],
      compensationFilter: {
        includeJobsWithUnspecifiedCompensationRange: false,
        range: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        type: '',
        units: []
      },
      customAttributeFilter: '',
      disableSpellCheck: false,
      employmentTypes: [],
      excludedJobs: [],
      jobCategories: [],
      languageCodes: [],
      locationFilters: [
        {
          address: '',
          distanceInMiles: '',
          latLng: {},
          regionCode: '',
          telecommutePreference: ''
        }
      ],
      publishTimeRange: {endTime: '', startTime: ''},
      query: '',
      queryLanguageCode: ''
    },
    jobView: '',
    offset: 0,
    orderBy: '',
    pageSize: 0,
    pageToken: '',
    requestMetadata: {deviceInfo: {deviceType: '', id: ''}, domain: '', sessionId: '', userId: ''},
    requirePreciseResultSize: false,
    searchMode: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"customRankingInfo":{"importanceLevel":"","rankingExpression":""},"disableKeywordMatch":false,"diversificationLevel":"","enableBroadening":false,"histogramFacets":{"compensationHistogramFacets":[{"bucketingOption":{"bucketBounds":[],"requiresMinMax":false},"type":""}],"customAttributeHistogramFacets":[{"key":"","longValueHistogramBucketingOption":{},"stringValueHistogram":false}],"simpleHistogramFacets":[]},"histogramQueries":[{"histogramQuery":""}],"jobQuery":{"commuteFilter":{"allowImpreciseAddresses":false,"commuteMethod":"","departureTime":{"hours":0,"minutes":0,"nanos":0,"seconds":0},"roadTraffic":"","startCoordinates":{"latitude":"","longitude":""},"travelDuration":""},"companyDisplayNames":[],"companyNames":[],"compensationFilter":{"includeJobsWithUnspecifiedCompensationRange":false,"range":{"maxCompensation":{"currencyCode":"","nanos":0,"units":""},"minCompensation":{}},"type":"","units":[]},"customAttributeFilter":"","disableSpellCheck":false,"employmentTypes":[],"excludedJobs":[],"jobCategories":[],"languageCodes":[],"locationFilters":[{"address":"","distanceInMiles":"","latLng":{},"regionCode":"","telecommutePreference":""}],"publishTimeRange":{"endTime":"","startTime":""},"query":"","queryLanguageCode":""},"jobView":"","offset":0,"orderBy":"","pageSize":0,"pageToken":"","requestMetadata":{"deviceInfo":{"deviceType":"","id":""},"domain":"","sessionId":"","userId":""},"requirePreciseResultSize":false,"searchMode":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "customRankingInfo": {\n    "importanceLevel": "",\n    "rankingExpression": ""\n  },\n  "disableKeywordMatch": false,\n  "diversificationLevel": "",\n  "enableBroadening": false,\n  "histogramFacets": {\n    "compensationHistogramFacets": [\n      {\n        "bucketingOption": {\n          "bucketBounds": [],\n          "requiresMinMax": false\n        },\n        "type": ""\n      }\n    ],\n    "customAttributeHistogramFacets": [\n      {\n        "key": "",\n        "longValueHistogramBucketingOption": {},\n        "stringValueHistogram": false\n      }\n    ],\n    "simpleHistogramFacets": []\n  },\n  "histogramQueries": [\n    {\n      "histogramQuery": ""\n    }\n  ],\n  "jobQuery": {\n    "commuteFilter": {\n      "allowImpreciseAddresses": false,\n      "commuteMethod": "",\n      "departureTime": {\n        "hours": 0,\n        "minutes": 0,\n        "nanos": 0,\n        "seconds": 0\n      },\n      "roadTraffic": "",\n      "startCoordinates": {\n        "latitude": "",\n        "longitude": ""\n      },\n      "travelDuration": ""\n    },\n    "companyDisplayNames": [],\n    "companyNames": [],\n    "compensationFilter": {\n      "includeJobsWithUnspecifiedCompensationRange": false,\n      "range": {\n        "maxCompensation": {\n          "currencyCode": "",\n          "nanos": 0,\n          "units": ""\n        },\n        "minCompensation": {}\n      },\n      "type": "",\n      "units": []\n    },\n    "customAttributeFilter": "",\n    "disableSpellCheck": false,\n    "employmentTypes": [],\n    "excludedJobs": [],\n    "jobCategories": [],\n    "languageCodes": [],\n    "locationFilters": [\n      {\n        "address": "",\n        "distanceInMiles": "",\n        "latLng": {},\n        "regionCode": "",\n        "telecommutePreference": ""\n      }\n    ],\n    "publishTimeRange": {\n      "endTime": "",\n      "startTime": ""\n    },\n    "query": "",\n    "queryLanguageCode": ""\n  },\n  "jobView": "",\n  "offset": 0,\n  "orderBy": "",\n  "pageSize": 0,\n  "pageToken": "",\n  "requestMetadata": {\n    "deviceInfo": {\n      "deviceType": "",\n      "id": ""\n    },\n    "domain": "",\n    "sessionId": "",\n    "userId": ""\n  },\n  "requirePreciseResultSize": false,\n  "searchMode": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert")
  .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/v3p1beta1/:parent/jobs:searchForAlert',
  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({
  customRankingInfo: {importanceLevel: '', rankingExpression: ''},
  disableKeywordMatch: false,
  diversificationLevel: '',
  enableBroadening: false,
  histogramFacets: {
    compensationHistogramFacets: [{bucketingOption: {bucketBounds: [], requiresMinMax: false}, type: ''}],
    customAttributeHistogramFacets: [{key: '', longValueHistogramBucketingOption: {}, stringValueHistogram: false}],
    simpleHistogramFacets: []
  },
  histogramQueries: [{histogramQuery: ''}],
  jobQuery: {
    commuteFilter: {
      allowImpreciseAddresses: false,
      commuteMethod: '',
      departureTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
      roadTraffic: '',
      startCoordinates: {latitude: '', longitude: ''},
      travelDuration: ''
    },
    companyDisplayNames: [],
    companyNames: [],
    compensationFilter: {
      includeJobsWithUnspecifiedCompensationRange: false,
      range: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
      type: '',
      units: []
    },
    customAttributeFilter: '',
    disableSpellCheck: false,
    employmentTypes: [],
    excludedJobs: [],
    jobCategories: [],
    languageCodes: [],
    locationFilters: [
      {
        address: '',
        distanceInMiles: '',
        latLng: {},
        regionCode: '',
        telecommutePreference: ''
      }
    ],
    publishTimeRange: {endTime: '', startTime: ''},
    query: '',
    queryLanguageCode: ''
  },
  jobView: '',
  offset: 0,
  orderBy: '',
  pageSize: 0,
  pageToken: '',
  requestMetadata: {deviceInfo: {deviceType: '', id: ''}, domain: '', sessionId: '', userId: ''},
  requirePreciseResultSize: false,
  searchMode: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert',
  headers: {'content-type': 'application/json'},
  body: {
    customRankingInfo: {importanceLevel: '', rankingExpression: ''},
    disableKeywordMatch: false,
    diversificationLevel: '',
    enableBroadening: false,
    histogramFacets: {
      compensationHistogramFacets: [{bucketingOption: {bucketBounds: [], requiresMinMax: false}, type: ''}],
      customAttributeHistogramFacets: [{key: '', longValueHistogramBucketingOption: {}, stringValueHistogram: false}],
      simpleHistogramFacets: []
    },
    histogramQueries: [{histogramQuery: ''}],
    jobQuery: {
      commuteFilter: {
        allowImpreciseAddresses: false,
        commuteMethod: '',
        departureTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
        roadTraffic: '',
        startCoordinates: {latitude: '', longitude: ''},
        travelDuration: ''
      },
      companyDisplayNames: [],
      companyNames: [],
      compensationFilter: {
        includeJobsWithUnspecifiedCompensationRange: false,
        range: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        type: '',
        units: []
      },
      customAttributeFilter: '',
      disableSpellCheck: false,
      employmentTypes: [],
      excludedJobs: [],
      jobCategories: [],
      languageCodes: [],
      locationFilters: [
        {
          address: '',
          distanceInMiles: '',
          latLng: {},
          regionCode: '',
          telecommutePreference: ''
        }
      ],
      publishTimeRange: {endTime: '', startTime: ''},
      query: '',
      queryLanguageCode: ''
    },
    jobView: '',
    offset: 0,
    orderBy: '',
    pageSize: 0,
    pageToken: '',
    requestMetadata: {deviceInfo: {deviceType: '', id: ''}, domain: '', sessionId: '', userId: ''},
    requirePreciseResultSize: false,
    searchMode: ''
  },
  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}}/v3p1beta1/:parent/jobs:searchForAlert');

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

req.type('json');
req.send({
  customRankingInfo: {
    importanceLevel: '',
    rankingExpression: ''
  },
  disableKeywordMatch: false,
  diversificationLevel: '',
  enableBroadening: false,
  histogramFacets: {
    compensationHistogramFacets: [
      {
        bucketingOption: {
          bucketBounds: [],
          requiresMinMax: false
        },
        type: ''
      }
    ],
    customAttributeHistogramFacets: [
      {
        key: '',
        longValueHistogramBucketingOption: {},
        stringValueHistogram: false
      }
    ],
    simpleHistogramFacets: []
  },
  histogramQueries: [
    {
      histogramQuery: ''
    }
  ],
  jobQuery: {
    commuteFilter: {
      allowImpreciseAddresses: false,
      commuteMethod: '',
      departureTime: {
        hours: 0,
        minutes: 0,
        nanos: 0,
        seconds: 0
      },
      roadTraffic: '',
      startCoordinates: {
        latitude: '',
        longitude: ''
      },
      travelDuration: ''
    },
    companyDisplayNames: [],
    companyNames: [],
    compensationFilter: {
      includeJobsWithUnspecifiedCompensationRange: false,
      range: {
        maxCompensation: {
          currencyCode: '',
          nanos: 0,
          units: ''
        },
        minCompensation: {}
      },
      type: '',
      units: []
    },
    customAttributeFilter: '',
    disableSpellCheck: false,
    employmentTypes: [],
    excludedJobs: [],
    jobCategories: [],
    languageCodes: [],
    locationFilters: [
      {
        address: '',
        distanceInMiles: '',
        latLng: {},
        regionCode: '',
        telecommutePreference: ''
      }
    ],
    publishTimeRange: {
      endTime: '',
      startTime: ''
    },
    query: '',
    queryLanguageCode: ''
  },
  jobView: '',
  offset: 0,
  orderBy: '',
  pageSize: 0,
  pageToken: '',
  requestMetadata: {
    deviceInfo: {
      deviceType: '',
      id: ''
    },
    domain: '',
    sessionId: '',
    userId: ''
  },
  requirePreciseResultSize: false,
  searchMode: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert',
  headers: {'content-type': 'application/json'},
  data: {
    customRankingInfo: {importanceLevel: '', rankingExpression: ''},
    disableKeywordMatch: false,
    diversificationLevel: '',
    enableBroadening: false,
    histogramFacets: {
      compensationHistogramFacets: [{bucketingOption: {bucketBounds: [], requiresMinMax: false}, type: ''}],
      customAttributeHistogramFacets: [{key: '', longValueHistogramBucketingOption: {}, stringValueHistogram: false}],
      simpleHistogramFacets: []
    },
    histogramQueries: [{histogramQuery: ''}],
    jobQuery: {
      commuteFilter: {
        allowImpreciseAddresses: false,
        commuteMethod: '',
        departureTime: {hours: 0, minutes: 0, nanos: 0, seconds: 0},
        roadTraffic: '',
        startCoordinates: {latitude: '', longitude: ''},
        travelDuration: ''
      },
      companyDisplayNames: [],
      companyNames: [],
      compensationFilter: {
        includeJobsWithUnspecifiedCompensationRange: false,
        range: {maxCompensation: {currencyCode: '', nanos: 0, units: ''}, minCompensation: {}},
        type: '',
        units: []
      },
      customAttributeFilter: '',
      disableSpellCheck: false,
      employmentTypes: [],
      excludedJobs: [],
      jobCategories: [],
      languageCodes: [],
      locationFilters: [
        {
          address: '',
          distanceInMiles: '',
          latLng: {},
          regionCode: '',
          telecommutePreference: ''
        }
      ],
      publishTimeRange: {endTime: '', startTime: ''},
      query: '',
      queryLanguageCode: ''
    },
    jobView: '',
    offset: 0,
    orderBy: '',
    pageSize: 0,
    pageToken: '',
    requestMetadata: {deviceInfo: {deviceType: '', id: ''}, domain: '', sessionId: '', userId: ''},
    requirePreciseResultSize: false,
    searchMode: ''
  }
};

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

const url = '{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"customRankingInfo":{"importanceLevel":"","rankingExpression":""},"disableKeywordMatch":false,"diversificationLevel":"","enableBroadening":false,"histogramFacets":{"compensationHistogramFacets":[{"bucketingOption":{"bucketBounds":[],"requiresMinMax":false},"type":""}],"customAttributeHistogramFacets":[{"key":"","longValueHistogramBucketingOption":{},"stringValueHistogram":false}],"simpleHistogramFacets":[]},"histogramQueries":[{"histogramQuery":""}],"jobQuery":{"commuteFilter":{"allowImpreciseAddresses":false,"commuteMethod":"","departureTime":{"hours":0,"minutes":0,"nanos":0,"seconds":0},"roadTraffic":"","startCoordinates":{"latitude":"","longitude":""},"travelDuration":""},"companyDisplayNames":[],"companyNames":[],"compensationFilter":{"includeJobsWithUnspecifiedCompensationRange":false,"range":{"maxCompensation":{"currencyCode":"","nanos":0,"units":""},"minCompensation":{}},"type":"","units":[]},"customAttributeFilter":"","disableSpellCheck":false,"employmentTypes":[],"excludedJobs":[],"jobCategories":[],"languageCodes":[],"locationFilters":[{"address":"","distanceInMiles":"","latLng":{},"regionCode":"","telecommutePreference":""}],"publishTimeRange":{"endTime":"","startTime":""},"query":"","queryLanguageCode":""},"jobView":"","offset":0,"orderBy":"","pageSize":0,"pageToken":"","requestMetadata":{"deviceInfo":{"deviceType":"","id":""},"domain":"","sessionId":"","userId":""},"requirePreciseResultSize":false,"searchMode":""}'
};

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 = @{ @"customRankingInfo": @{ @"importanceLevel": @"", @"rankingExpression": @"" },
                              @"disableKeywordMatch": @NO,
                              @"diversificationLevel": @"",
                              @"enableBroadening": @NO,
                              @"histogramFacets": @{ @"compensationHistogramFacets": @[ @{ @"bucketingOption": @{ @"bucketBounds": @[  ], @"requiresMinMax": @NO }, @"type": @"" } ], @"customAttributeHistogramFacets": @[ @{ @"key": @"", @"longValueHistogramBucketingOption": @{  }, @"stringValueHistogram": @NO } ], @"simpleHistogramFacets": @[  ] },
                              @"histogramQueries": @[ @{ @"histogramQuery": @"" } ],
                              @"jobQuery": @{ @"commuteFilter": @{ @"allowImpreciseAddresses": @NO, @"commuteMethod": @"", @"departureTime": @{ @"hours": @0, @"minutes": @0, @"nanos": @0, @"seconds": @0 }, @"roadTraffic": @"", @"startCoordinates": @{ @"latitude": @"", @"longitude": @"" }, @"travelDuration": @"" }, @"companyDisplayNames": @[  ], @"companyNames": @[  ], @"compensationFilter": @{ @"includeJobsWithUnspecifiedCompensationRange": @NO, @"range": @{ @"maxCompensation": @{ @"currencyCode": @"", @"nanos": @0, @"units": @"" }, @"minCompensation": @{  } }, @"type": @"", @"units": @[  ] }, @"customAttributeFilter": @"", @"disableSpellCheck": @NO, @"employmentTypes": @[  ], @"excludedJobs": @[  ], @"jobCategories": @[  ], @"languageCodes": @[  ], @"locationFilters": @[ @{ @"address": @"", @"distanceInMiles": @"", @"latLng": @{  }, @"regionCode": @"", @"telecommutePreference": @"" } ], @"publishTimeRange": @{ @"endTime": @"", @"startTime": @"" }, @"query": @"", @"queryLanguageCode": @"" },
                              @"jobView": @"",
                              @"offset": @0,
                              @"orderBy": @"",
                              @"pageSize": @0,
                              @"pageToken": @"",
                              @"requestMetadata": @{ @"deviceInfo": @{ @"deviceType": @"", @"id": @"" }, @"domain": @"", @"sessionId": @"", @"userId": @"" },
                              @"requirePreciseResultSize": @NO,
                              @"searchMode": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert"]
                                                       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}}/v3p1beta1/:parent/jobs:searchForAlert" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert",
  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([
    'customRankingInfo' => [
        'importanceLevel' => '',
        'rankingExpression' => ''
    ],
    'disableKeywordMatch' => null,
    'diversificationLevel' => '',
    'enableBroadening' => null,
    'histogramFacets' => [
        'compensationHistogramFacets' => [
                [
                                'bucketingOption' => [
                                                                'bucketBounds' => [
                                                                                                                                
                                                                ],
                                                                'requiresMinMax' => null
                                ],
                                'type' => ''
                ]
        ],
        'customAttributeHistogramFacets' => [
                [
                                'key' => '',
                                'longValueHistogramBucketingOption' => [
                                                                
                                ],
                                'stringValueHistogram' => null
                ]
        ],
        'simpleHistogramFacets' => [
                
        ]
    ],
    'histogramQueries' => [
        [
                'histogramQuery' => ''
        ]
    ],
    'jobQuery' => [
        'commuteFilter' => [
                'allowImpreciseAddresses' => null,
                'commuteMethod' => '',
                'departureTime' => [
                                'hours' => 0,
                                'minutes' => 0,
                                'nanos' => 0,
                                'seconds' => 0
                ],
                'roadTraffic' => '',
                'startCoordinates' => [
                                'latitude' => '',
                                'longitude' => ''
                ],
                'travelDuration' => ''
        ],
        'companyDisplayNames' => [
                
        ],
        'companyNames' => [
                
        ],
        'compensationFilter' => [
                'includeJobsWithUnspecifiedCompensationRange' => null,
                'range' => [
                                'maxCompensation' => [
                                                                'currencyCode' => '',
                                                                'nanos' => 0,
                                                                'units' => ''
                                ],
                                'minCompensation' => [
                                                                
                                ]
                ],
                'type' => '',
                'units' => [
                                
                ]
        ],
        'customAttributeFilter' => '',
        'disableSpellCheck' => null,
        'employmentTypes' => [
                
        ],
        'excludedJobs' => [
                
        ],
        'jobCategories' => [
                
        ],
        'languageCodes' => [
                
        ],
        'locationFilters' => [
                [
                                'address' => '',
                                'distanceInMiles' => '',
                                'latLng' => [
                                                                
                                ],
                                'regionCode' => '',
                                'telecommutePreference' => ''
                ]
        ],
        'publishTimeRange' => [
                'endTime' => '',
                'startTime' => ''
        ],
        'query' => '',
        'queryLanguageCode' => ''
    ],
    'jobView' => '',
    'offset' => 0,
    'orderBy' => '',
    'pageSize' => 0,
    'pageToken' => '',
    'requestMetadata' => [
        'deviceInfo' => [
                'deviceType' => '',
                'id' => ''
        ],
        'domain' => '',
        'sessionId' => '',
        'userId' => ''
    ],
    'requirePreciseResultSize' => null,
    'searchMode' => ''
  ]),
  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}}/v3p1beta1/:parent/jobs:searchForAlert', [
  'body' => '{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'customRankingInfo' => [
    'importanceLevel' => '',
    'rankingExpression' => ''
  ],
  'disableKeywordMatch' => null,
  'diversificationLevel' => '',
  'enableBroadening' => null,
  'histogramFacets' => [
    'compensationHistogramFacets' => [
        [
                'bucketingOption' => [
                                'bucketBounds' => [
                                                                
                                ],
                                'requiresMinMax' => null
                ],
                'type' => ''
        ]
    ],
    'customAttributeHistogramFacets' => [
        [
                'key' => '',
                'longValueHistogramBucketingOption' => [
                                
                ],
                'stringValueHistogram' => null
        ]
    ],
    'simpleHistogramFacets' => [
        
    ]
  ],
  'histogramQueries' => [
    [
        'histogramQuery' => ''
    ]
  ],
  'jobQuery' => [
    'commuteFilter' => [
        'allowImpreciseAddresses' => null,
        'commuteMethod' => '',
        'departureTime' => [
                'hours' => 0,
                'minutes' => 0,
                'nanos' => 0,
                'seconds' => 0
        ],
        'roadTraffic' => '',
        'startCoordinates' => [
                'latitude' => '',
                'longitude' => ''
        ],
        'travelDuration' => ''
    ],
    'companyDisplayNames' => [
        
    ],
    'companyNames' => [
        
    ],
    'compensationFilter' => [
        'includeJobsWithUnspecifiedCompensationRange' => null,
        'range' => [
                'maxCompensation' => [
                                'currencyCode' => '',
                                'nanos' => 0,
                                'units' => ''
                ],
                'minCompensation' => [
                                
                ]
        ],
        'type' => '',
        'units' => [
                
        ]
    ],
    'customAttributeFilter' => '',
    'disableSpellCheck' => null,
    'employmentTypes' => [
        
    ],
    'excludedJobs' => [
        
    ],
    'jobCategories' => [
        
    ],
    'languageCodes' => [
        
    ],
    'locationFilters' => [
        [
                'address' => '',
                'distanceInMiles' => '',
                'latLng' => [
                                
                ],
                'regionCode' => '',
                'telecommutePreference' => ''
        ]
    ],
    'publishTimeRange' => [
        'endTime' => '',
        'startTime' => ''
    ],
    'query' => '',
    'queryLanguageCode' => ''
  ],
  'jobView' => '',
  'offset' => 0,
  'orderBy' => '',
  'pageSize' => 0,
  'pageToken' => '',
  'requestMetadata' => [
    'deviceInfo' => [
        'deviceType' => '',
        'id' => ''
    ],
    'domain' => '',
    'sessionId' => '',
    'userId' => ''
  ],
  'requirePreciseResultSize' => null,
  'searchMode' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'customRankingInfo' => [
    'importanceLevel' => '',
    'rankingExpression' => ''
  ],
  'disableKeywordMatch' => null,
  'diversificationLevel' => '',
  'enableBroadening' => null,
  'histogramFacets' => [
    'compensationHistogramFacets' => [
        [
                'bucketingOption' => [
                                'bucketBounds' => [
                                                                
                                ],
                                'requiresMinMax' => null
                ],
                'type' => ''
        ]
    ],
    'customAttributeHistogramFacets' => [
        [
                'key' => '',
                'longValueHistogramBucketingOption' => [
                                
                ],
                'stringValueHistogram' => null
        ]
    ],
    'simpleHistogramFacets' => [
        
    ]
  ],
  'histogramQueries' => [
    [
        'histogramQuery' => ''
    ]
  ],
  'jobQuery' => [
    'commuteFilter' => [
        'allowImpreciseAddresses' => null,
        'commuteMethod' => '',
        'departureTime' => [
                'hours' => 0,
                'minutes' => 0,
                'nanos' => 0,
                'seconds' => 0
        ],
        'roadTraffic' => '',
        'startCoordinates' => [
                'latitude' => '',
                'longitude' => ''
        ],
        'travelDuration' => ''
    ],
    'companyDisplayNames' => [
        
    ],
    'companyNames' => [
        
    ],
    'compensationFilter' => [
        'includeJobsWithUnspecifiedCompensationRange' => null,
        'range' => [
                'maxCompensation' => [
                                'currencyCode' => '',
                                'nanos' => 0,
                                'units' => ''
                ],
                'minCompensation' => [
                                
                ]
        ],
        'type' => '',
        'units' => [
                
        ]
    ],
    'customAttributeFilter' => '',
    'disableSpellCheck' => null,
    'employmentTypes' => [
        
    ],
    'excludedJobs' => [
        
    ],
    'jobCategories' => [
        
    ],
    'languageCodes' => [
        
    ],
    'locationFilters' => [
        [
                'address' => '',
                'distanceInMiles' => '',
                'latLng' => [
                                
                ],
                'regionCode' => '',
                'telecommutePreference' => ''
        ]
    ],
    'publishTimeRange' => [
        'endTime' => '',
        'startTime' => ''
    ],
    'query' => '',
    'queryLanguageCode' => ''
  ],
  'jobView' => '',
  'offset' => 0,
  'orderBy' => '',
  'pageSize' => 0,
  'pageToken' => '',
  'requestMetadata' => [
    'deviceInfo' => [
        'deviceType' => '',
        'id' => ''
    ],
    'domain' => '',
    'sessionId' => '',
    'userId' => ''
  ],
  'requirePreciseResultSize' => null,
  'searchMode' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert');
$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}}/v3p1beta1/:parent/jobs:searchForAlert' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}'
import http.client

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

payload = "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v3p1beta1/:parent/jobs:searchForAlert", payload, headers)

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

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

url = "{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert"

payload = {
    "customRankingInfo": {
        "importanceLevel": "",
        "rankingExpression": ""
    },
    "disableKeywordMatch": False,
    "diversificationLevel": "",
    "enableBroadening": False,
    "histogramFacets": {
        "compensationHistogramFacets": [
            {
                "bucketingOption": {
                    "bucketBounds": [],
                    "requiresMinMax": False
                },
                "type": ""
            }
        ],
        "customAttributeHistogramFacets": [
            {
                "key": "",
                "longValueHistogramBucketingOption": {},
                "stringValueHistogram": False
            }
        ],
        "simpleHistogramFacets": []
    },
    "histogramQueries": [{ "histogramQuery": "" }],
    "jobQuery": {
        "commuteFilter": {
            "allowImpreciseAddresses": False,
            "commuteMethod": "",
            "departureTime": {
                "hours": 0,
                "minutes": 0,
                "nanos": 0,
                "seconds": 0
            },
            "roadTraffic": "",
            "startCoordinates": {
                "latitude": "",
                "longitude": ""
            },
            "travelDuration": ""
        },
        "companyDisplayNames": [],
        "companyNames": [],
        "compensationFilter": {
            "includeJobsWithUnspecifiedCompensationRange": False,
            "range": {
                "maxCompensation": {
                    "currencyCode": "",
                    "nanos": 0,
                    "units": ""
                },
                "minCompensation": {}
            },
            "type": "",
            "units": []
        },
        "customAttributeFilter": "",
        "disableSpellCheck": False,
        "employmentTypes": [],
        "excludedJobs": [],
        "jobCategories": [],
        "languageCodes": [],
        "locationFilters": [
            {
                "address": "",
                "distanceInMiles": "",
                "latLng": {},
                "regionCode": "",
                "telecommutePreference": ""
            }
        ],
        "publishTimeRange": {
            "endTime": "",
            "startTime": ""
        },
        "query": "",
        "queryLanguageCode": ""
    },
    "jobView": "",
    "offset": 0,
    "orderBy": "",
    "pageSize": 0,
    "pageToken": "",
    "requestMetadata": {
        "deviceInfo": {
            "deviceType": "",
            "id": ""
        },
        "domain": "",
        "sessionId": "",
        "userId": ""
    },
    "requirePreciseResultSize": False,
    "searchMode": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert"

payload <- "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\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}}/v3p1beta1/:parent/jobs:searchForAlert")

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  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}"

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/v3p1beta1/:parent/jobs:searchForAlert') do |req|
  req.body = "{\n  \"customRankingInfo\": {\n    \"importanceLevel\": \"\",\n    \"rankingExpression\": \"\"\n  },\n  \"disableKeywordMatch\": false,\n  \"diversificationLevel\": \"\",\n  \"enableBroadening\": false,\n  \"histogramFacets\": {\n    \"compensationHistogramFacets\": [\n      {\n        \"bucketingOption\": {\n          \"bucketBounds\": [],\n          \"requiresMinMax\": false\n        },\n        \"type\": \"\"\n      }\n    ],\n    \"customAttributeHistogramFacets\": [\n      {\n        \"key\": \"\",\n        \"longValueHistogramBucketingOption\": {},\n        \"stringValueHistogram\": false\n      }\n    ],\n    \"simpleHistogramFacets\": []\n  },\n  \"histogramQueries\": [\n    {\n      \"histogramQuery\": \"\"\n    }\n  ],\n  \"jobQuery\": {\n    \"commuteFilter\": {\n      \"allowImpreciseAddresses\": false,\n      \"commuteMethod\": \"\",\n      \"departureTime\": {\n        \"hours\": 0,\n        \"minutes\": 0,\n        \"nanos\": 0,\n        \"seconds\": 0\n      },\n      \"roadTraffic\": \"\",\n      \"startCoordinates\": {\n        \"latitude\": \"\",\n        \"longitude\": \"\"\n      },\n      \"travelDuration\": \"\"\n    },\n    \"companyDisplayNames\": [],\n    \"companyNames\": [],\n    \"compensationFilter\": {\n      \"includeJobsWithUnspecifiedCompensationRange\": false,\n      \"range\": {\n        \"maxCompensation\": {\n          \"currencyCode\": \"\",\n          \"nanos\": 0,\n          \"units\": \"\"\n        },\n        \"minCompensation\": {}\n      },\n      \"type\": \"\",\n      \"units\": []\n    },\n    \"customAttributeFilter\": \"\",\n    \"disableSpellCheck\": false,\n    \"employmentTypes\": [],\n    \"excludedJobs\": [],\n    \"jobCategories\": [],\n    \"languageCodes\": [],\n    \"locationFilters\": [\n      {\n        \"address\": \"\",\n        \"distanceInMiles\": \"\",\n        \"latLng\": {},\n        \"regionCode\": \"\",\n        \"telecommutePreference\": \"\"\n      }\n    ],\n    \"publishTimeRange\": {\n      \"endTime\": \"\",\n      \"startTime\": \"\"\n    },\n    \"query\": \"\",\n    \"queryLanguageCode\": \"\"\n  },\n  \"jobView\": \"\",\n  \"offset\": 0,\n  \"orderBy\": \"\",\n  \"pageSize\": 0,\n  \"pageToken\": \"\",\n  \"requestMetadata\": {\n    \"deviceInfo\": {\n      \"deviceType\": \"\",\n      \"id\": \"\"\n    },\n    \"domain\": \"\",\n    \"sessionId\": \"\",\n    \"userId\": \"\"\n  },\n  \"requirePreciseResultSize\": false,\n  \"searchMode\": \"\"\n}"
end

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

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

    let payload = json!({
        "customRankingInfo": json!({
            "importanceLevel": "",
            "rankingExpression": ""
        }),
        "disableKeywordMatch": false,
        "diversificationLevel": "",
        "enableBroadening": false,
        "histogramFacets": json!({
            "compensationHistogramFacets": (
                json!({
                    "bucketingOption": json!({
                        "bucketBounds": (),
                        "requiresMinMax": false
                    }),
                    "type": ""
                })
            ),
            "customAttributeHistogramFacets": (
                json!({
                    "key": "",
                    "longValueHistogramBucketingOption": json!({}),
                    "stringValueHistogram": false
                })
            ),
            "simpleHistogramFacets": ()
        }),
        "histogramQueries": (json!({"histogramQuery": ""})),
        "jobQuery": json!({
            "commuteFilter": json!({
                "allowImpreciseAddresses": false,
                "commuteMethod": "",
                "departureTime": json!({
                    "hours": 0,
                    "minutes": 0,
                    "nanos": 0,
                    "seconds": 0
                }),
                "roadTraffic": "",
                "startCoordinates": json!({
                    "latitude": "",
                    "longitude": ""
                }),
                "travelDuration": ""
            }),
            "companyDisplayNames": (),
            "companyNames": (),
            "compensationFilter": json!({
                "includeJobsWithUnspecifiedCompensationRange": false,
                "range": json!({
                    "maxCompensation": json!({
                        "currencyCode": "",
                        "nanos": 0,
                        "units": ""
                    }),
                    "minCompensation": json!({})
                }),
                "type": "",
                "units": ()
            }),
            "customAttributeFilter": "",
            "disableSpellCheck": false,
            "employmentTypes": (),
            "excludedJobs": (),
            "jobCategories": (),
            "languageCodes": (),
            "locationFilters": (
                json!({
                    "address": "",
                    "distanceInMiles": "",
                    "latLng": json!({}),
                    "regionCode": "",
                    "telecommutePreference": ""
                })
            ),
            "publishTimeRange": json!({
                "endTime": "",
                "startTime": ""
            }),
            "query": "",
            "queryLanguageCode": ""
        }),
        "jobView": "",
        "offset": 0,
        "orderBy": "",
        "pageSize": 0,
        "pageToken": "",
        "requestMetadata": json!({
            "deviceInfo": json!({
                "deviceType": "",
                "id": ""
            }),
            "domain": "",
            "sessionId": "",
            "userId": ""
        }),
        "requirePreciseResultSize": false,
        "searchMode": ""
    });

    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}}/v3p1beta1/:parent/jobs:searchForAlert \
  --header 'content-type: application/json' \
  --data '{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}'
echo '{
  "customRankingInfo": {
    "importanceLevel": "",
    "rankingExpression": ""
  },
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": {
    "compensationHistogramFacets": [
      {
        "bucketingOption": {
          "bucketBounds": [],
          "requiresMinMax": false
        },
        "type": ""
      }
    ],
    "customAttributeHistogramFacets": [
      {
        "key": "",
        "longValueHistogramBucketingOption": {},
        "stringValueHistogram": false
      }
    ],
    "simpleHistogramFacets": []
  },
  "histogramQueries": [
    {
      "histogramQuery": ""
    }
  ],
  "jobQuery": {
    "commuteFilter": {
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": {
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      },
      "roadTraffic": "",
      "startCoordinates": {
        "latitude": "",
        "longitude": ""
      },
      "travelDuration": ""
    },
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": {
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": {
        "maxCompensation": {
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        },
        "minCompensation": {}
      },
      "type": "",
      "units": []
    },
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      {
        "address": "",
        "distanceInMiles": "",
        "latLng": {},
        "regionCode": "",
        "telecommutePreference": ""
      }
    ],
    "publishTimeRange": {
      "endTime": "",
      "startTime": ""
    },
    "query": "",
    "queryLanguageCode": ""
  },
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": {
    "deviceInfo": {
      "deviceType": "",
      "id": ""
    },
    "domain": "",
    "sessionId": "",
    "userId": ""
  },
  "requirePreciseResultSize": false,
  "searchMode": ""
}' |  \
  http POST {{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "customRankingInfo": {\n    "importanceLevel": "",\n    "rankingExpression": ""\n  },\n  "disableKeywordMatch": false,\n  "diversificationLevel": "",\n  "enableBroadening": false,\n  "histogramFacets": {\n    "compensationHistogramFacets": [\n      {\n        "bucketingOption": {\n          "bucketBounds": [],\n          "requiresMinMax": false\n        },\n        "type": ""\n      }\n    ],\n    "customAttributeHistogramFacets": [\n      {\n        "key": "",\n        "longValueHistogramBucketingOption": {},\n        "stringValueHistogram": false\n      }\n    ],\n    "simpleHistogramFacets": []\n  },\n  "histogramQueries": [\n    {\n      "histogramQuery": ""\n    }\n  ],\n  "jobQuery": {\n    "commuteFilter": {\n      "allowImpreciseAddresses": false,\n      "commuteMethod": "",\n      "departureTime": {\n        "hours": 0,\n        "minutes": 0,\n        "nanos": 0,\n        "seconds": 0\n      },\n      "roadTraffic": "",\n      "startCoordinates": {\n        "latitude": "",\n        "longitude": ""\n      },\n      "travelDuration": ""\n    },\n    "companyDisplayNames": [],\n    "companyNames": [],\n    "compensationFilter": {\n      "includeJobsWithUnspecifiedCompensationRange": false,\n      "range": {\n        "maxCompensation": {\n          "currencyCode": "",\n          "nanos": 0,\n          "units": ""\n        },\n        "minCompensation": {}\n      },\n      "type": "",\n      "units": []\n    },\n    "customAttributeFilter": "",\n    "disableSpellCheck": false,\n    "employmentTypes": [],\n    "excludedJobs": [],\n    "jobCategories": [],\n    "languageCodes": [],\n    "locationFilters": [\n      {\n        "address": "",\n        "distanceInMiles": "",\n        "latLng": {},\n        "regionCode": "",\n        "telecommutePreference": ""\n      }\n    ],\n    "publishTimeRange": {\n      "endTime": "",\n      "startTime": ""\n    },\n    "query": "",\n    "queryLanguageCode": ""\n  },\n  "jobView": "",\n  "offset": 0,\n  "orderBy": "",\n  "pageSize": 0,\n  "pageToken": "",\n  "requestMetadata": {\n    "deviceInfo": {\n      "deviceType": "",\n      "id": ""\n    },\n    "domain": "",\n    "sessionId": "",\n    "userId": ""\n  },\n  "requirePreciseResultSize": false,\n  "searchMode": ""\n}' \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "customRankingInfo": [
    "importanceLevel": "",
    "rankingExpression": ""
  ],
  "disableKeywordMatch": false,
  "diversificationLevel": "",
  "enableBroadening": false,
  "histogramFacets": [
    "compensationHistogramFacets": [
      [
        "bucketingOption": [
          "bucketBounds": [],
          "requiresMinMax": false
        ],
        "type": ""
      ]
    ],
    "customAttributeHistogramFacets": [
      [
        "key": "",
        "longValueHistogramBucketingOption": [],
        "stringValueHistogram": false
      ]
    ],
    "simpleHistogramFacets": []
  ],
  "histogramQueries": [["histogramQuery": ""]],
  "jobQuery": [
    "commuteFilter": [
      "allowImpreciseAddresses": false,
      "commuteMethod": "",
      "departureTime": [
        "hours": 0,
        "minutes": 0,
        "nanos": 0,
        "seconds": 0
      ],
      "roadTraffic": "",
      "startCoordinates": [
        "latitude": "",
        "longitude": ""
      ],
      "travelDuration": ""
    ],
    "companyDisplayNames": [],
    "companyNames": [],
    "compensationFilter": [
      "includeJobsWithUnspecifiedCompensationRange": false,
      "range": [
        "maxCompensation": [
          "currencyCode": "",
          "nanos": 0,
          "units": ""
        ],
        "minCompensation": []
      ],
      "type": "",
      "units": []
    ],
    "customAttributeFilter": "",
    "disableSpellCheck": false,
    "employmentTypes": [],
    "excludedJobs": [],
    "jobCategories": [],
    "languageCodes": [],
    "locationFilters": [
      [
        "address": "",
        "distanceInMiles": "",
        "latLng": [],
        "regionCode": "",
        "telecommutePreference": ""
      ]
    ],
    "publishTimeRange": [
      "endTime": "",
      "startTime": ""
    ],
    "query": "",
    "queryLanguageCode": ""
  ],
  "jobView": "",
  "offset": 0,
  "orderBy": "",
  "pageSize": 0,
  "pageToken": "",
  "requestMetadata": [
    "deviceInfo": [
      "deviceType": "",
      "id": ""
    ],
    "domain": "",
    "sessionId": "",
    "userId": ""
  ],
  "requirePreciseResultSize": false,
  "searchMode": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3p1beta1/:parent/jobs:searchForAlert")! 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 jobs.projects.operations.get
{{baseUrl}}/v3p1beta1/: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}}/v3p1beta1/:name");

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

(client/get "{{baseUrl}}/v3p1beta1/:name")
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/v3p1beta1/: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/v3p1beta1/:name HTTP/1.1
Host: example.com

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v3p1beta1/: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}}/v3p1beta1/:name")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v3p1beta1/: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}}/v3p1beta1/:name');

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

const options = {method: 'GET', url: '{{baseUrl}}/v3p1beta1/:name'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v3p1beta1/:name")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v3p1beta1/: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}}/v3p1beta1/: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}}/v3p1beta1/: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}}/v3p1beta1/:name'};

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

const url = '{{baseUrl}}/v3p1beta1/: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}}/v3p1beta1/: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}}/v3p1beta1/:name" in

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

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

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

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

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

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

conn.request("GET", "/baseUrl/v3p1beta1/:name")

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

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

url = "{{baseUrl}}/v3p1beta1/:name"

response = requests.get(url)

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

url <- "{{baseUrl}}/v3p1beta1/:name"

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

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

url = URI("{{baseUrl}}/v3p1beta1/: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/v3p1beta1/:name') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v3p1beta1/: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}}/v3p1beta1/:name
http GET {{baseUrl}}/v3p1beta1/:name
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v3p1beta1/:name
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v3p1beta1/: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()