POST ml.projects.explain
{{baseUrl}}/v1/:name:explain
QUERY PARAMS

name
BODY json

{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:name:explain");

struct curl_slist *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  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}");

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

(client/post "{{baseUrl}}/v1/:name:explain" {:content-type :json
                                                             :form-params {:httpBody {:contentType ""
                                                                                      :data ""
                                                                                      :extensions [{}]}}})
require "http/client"

url = "{{baseUrl}}/v1/:name:explain"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:name:explain"),
    Content = new StringContent("{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:name:explain");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1/:name:explain"

	payload := strings.NewReader("{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v1/:name:explain HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 97

{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:name:explain")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:name:explain"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:name:explain")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:name:explain")
  .header("content-type", "application/json")
  .body("{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  httpBody: {
    contentType: '',
    data: '',
    extensions: [
      {}
    ]
  }
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:explain',
  headers: {'content-type': 'application/json'},
  data: {httpBody: {contentType: '', data: '', extensions: [{}]}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:name:explain';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"httpBody":{"contentType":"","data":"","extensions":[{}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:name:explain',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "httpBody": {\n    "contentType": "",\n    "data": "",\n    "extensions": [\n      {}\n    ]\n  }\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:name:explain")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:name:explain',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({httpBody: {contentType: '', data: '', extensions: [{}]}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:explain',
  headers: {'content-type': 'application/json'},
  body: {httpBody: {contentType: '', data: '', extensions: [{}]}},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v1/:name:explain');

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

req.type('json');
req.send({
  httpBody: {
    contentType: '',
    data: '',
    extensions: [
      {}
    ]
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:explain',
  headers: {'content-type': 'application/json'},
  data: {httpBody: {contentType: '', data: '', extensions: [{}]}}
};

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

const url = '{{baseUrl}}/v1/:name:explain';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"httpBody":{"contentType":"","data":"","extensions":[{}]}}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"httpBody": @{ @"contentType": @"", @"data": @"", @"extensions": @[ @{  } ] } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:name:explain" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:name:explain",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'httpBody' => [
        'contentType' => '',
        'data' => '',
        'extensions' => [
                [
                                
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:name:explain', [
  'body' => '{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:name:explain');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'httpBody' => [
    'contentType' => '',
    'data' => '',
    'extensions' => [
        [
                
        ]
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'httpBody' => [
    'contentType' => '',
    'data' => '',
    'extensions' => [
        [
                
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v1/:name:explain');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:name:explain' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name:explain' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}'
import http.client

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

payload = "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"

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

conn.request("POST", "/baseUrl/v1/:name:explain", payload, headers)

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

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

url = "{{baseUrl}}/v1/:name:explain"

payload = { "httpBody": {
        "contentType": "",
        "data": "",
        "extensions": [{}]
    } }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1/:name:explain"

payload <- "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"

encode <- "json"

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

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

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

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  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"

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

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

response = conn.post('/baseUrl/v1/:name:explain') do |req|
  req.body = "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"
end

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

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

    let payload = json!({"httpBody": json!({
            "contentType": "",
            "data": "",
            "extensions": (json!({}))
        })});

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:name:explain \
  --header 'content-type: application/json' \
  --data '{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}'
echo '{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}' |  \
  http POST {{baseUrl}}/v1/:name:explain \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "httpBody": {\n    "contentType": "",\n    "data": "",\n    "extensions": [\n      {}\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v1/:name:explain
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["httpBody": [
    "contentType": "",
    "data": "",
    "extensions": [[]]
  ]] as [String : Any]

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

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

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

dataTask.resume()
GET ml.projects.getConfig
{{baseUrl}}/v1/:name:getConfig
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

url = "{{baseUrl}}/v1/:name:getConfig"

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

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

func main() {

	url := "{{baseUrl}}/v1/:name:getConfig"

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

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

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

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

}
GET /baseUrl/v1/:name:getConfig HTTP/1.1
Host: example.com

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

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

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

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

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

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

xhr.open('GET', '{{baseUrl}}/v1/:name:getConfig');

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

const url = '{{baseUrl}}/v1/:name:getConfig';
const options = {method: 'GET'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:name:getConfig"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

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

let uri = Uri.of_string "{{baseUrl}}/v1/:name:getConfig" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v1/:name:getConfig');

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

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

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

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

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

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

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

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

url = "{{baseUrl}}/v1/:name:getConfig"

response = requests.get(url)

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

url <- "{{baseUrl}}/v1/:name:getConfig"

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

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

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

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

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

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

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

response = conn.get('/baseUrl/v1/:name:getConfig') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

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

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

parent
BODY json

{
  "createTime": "",
  "endTime": "",
  "errorMessage": "",
  "etag": "",
  "jobId": "",
  "jobPosition": "",
  "labels": {},
  "predictionInput": {
    "batchSize": "",
    "dataFormat": "",
    "inputPaths": [],
    "maxWorkerCount": "",
    "modelName": "",
    "outputDataFormat": "",
    "outputPath": "",
    "region": "",
    "runtimeVersion": "",
    "signatureName": "",
    "uri": "",
    "versionName": ""
  },
  "predictionOutput": {
    "errorCount": "",
    "nodeHours": "",
    "outputPath": "",
    "predictionCount": ""
  },
  "startTime": "",
  "state": "",
  "trainingInput": {
    "args": [],
    "enableWebAccess": false,
    "encryptionConfig": {
      "kmsKeyName": ""
    },
    "evaluatorConfig": {
      "acceleratorConfig": {
        "count": "",
        "type": ""
      },
      "containerArgs": [],
      "containerCommand": [],
      "diskConfig": {
        "bootDiskSizeGb": 0,
        "bootDiskType": ""
      },
      "imageUri": "",
      "tpuTfVersion": ""
    },
    "evaluatorCount": "",
    "evaluatorType": "",
    "hyperparameters": {
      "algorithm": "",
      "enableTrialEarlyStopping": false,
      "goal": "",
      "hyperparameterMetricTag": "",
      "maxFailedTrials": 0,
      "maxParallelTrials": 0,
      "maxTrials": 0,
      "params": [
        {
          "categoricalValues": [],
          "discreteValues": [],
          "maxValue": "",
          "minValue": "",
          "parameterName": "",
          "scaleType": "",
          "type": ""
        }
      ],
      "resumePreviousJobId": ""
    },
    "jobDir": "",
    "masterConfig": {},
    "masterType": "",
    "network": "",
    "packageUris": [],
    "parameterServerConfig": {},
    "parameterServerCount": "",
    "parameterServerType": "",
    "pythonModule": "",
    "pythonVersion": "",
    "region": "",
    "runtimeVersion": "",
    "scaleTier": "",
    "scheduling": {
      "maxRunningTime": "",
      "maxWaitTime": "",
      "priority": 0
    },
    "serviceAccount": "",
    "useChiefInTfConfig": false,
    "workerConfig": {},
    "workerCount": "",
    "workerType": ""
  },
  "trainingOutput": {
    "builtInAlgorithmOutput": {
      "framework": "",
      "modelPath": "",
      "pythonVersion": "",
      "runtimeVersion": ""
    },
    "completedTrialCount": "",
    "consumedMLUnits": "",
    "hyperparameterMetricTag": "",
    "isBuiltInAlgorithmJob": false,
    "isHyperparameterTuningJob": false,
    "trials": [
      {
        "allMetrics": [
          {
            "objectiveValue": "",
            "trainingStep": ""
          }
        ],
        "builtInAlgorithmOutput": {},
        "endTime": "",
        "finalMetric": {},
        "hyperparameters": {},
        "isTrialStoppedEarly": false,
        "startTime": "",
        "state": "",
        "trialId": "",
        "webAccessUris": {}
      }
    ],
    "webAccessUris": {}
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/: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  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}");

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

(client/post "{{baseUrl}}/v1/:parent/jobs" {:content-type :json
                                                            :form-params {:createTime ""
                                                                          :endTime ""
                                                                          :errorMessage ""
                                                                          :etag ""
                                                                          :jobId ""
                                                                          :jobPosition ""
                                                                          :labels {}
                                                                          :predictionInput {:batchSize ""
                                                                                            :dataFormat ""
                                                                                            :inputPaths []
                                                                                            :maxWorkerCount ""
                                                                                            :modelName ""
                                                                                            :outputDataFormat ""
                                                                                            :outputPath ""
                                                                                            :region ""
                                                                                            :runtimeVersion ""
                                                                                            :signatureName ""
                                                                                            :uri ""
                                                                                            :versionName ""}
                                                                          :predictionOutput {:errorCount ""
                                                                                             :nodeHours ""
                                                                                             :outputPath ""
                                                                                             :predictionCount ""}
                                                                          :startTime ""
                                                                          :state ""
                                                                          :trainingInput {:args []
                                                                                          :enableWebAccess false
                                                                                          :encryptionConfig {:kmsKeyName ""}
                                                                                          :evaluatorConfig {:acceleratorConfig {:count ""
                                                                                                                                :type ""}
                                                                                                            :containerArgs []
                                                                                                            :containerCommand []
                                                                                                            :diskConfig {:bootDiskSizeGb 0
                                                                                                                         :bootDiskType ""}
                                                                                                            :imageUri ""
                                                                                                            :tpuTfVersion ""}
                                                                                          :evaluatorCount ""
                                                                                          :evaluatorType ""
                                                                                          :hyperparameters {:algorithm ""
                                                                                                            :enableTrialEarlyStopping false
                                                                                                            :goal ""
                                                                                                            :hyperparameterMetricTag ""
                                                                                                            :maxFailedTrials 0
                                                                                                            :maxParallelTrials 0
                                                                                                            :maxTrials 0
                                                                                                            :params [{:categoricalValues []
                                                                                                                      :discreteValues []
                                                                                                                      :maxValue ""
                                                                                                                      :minValue ""
                                                                                                                      :parameterName ""
                                                                                                                      :scaleType ""
                                                                                                                      :type ""}]
                                                                                                            :resumePreviousJobId ""}
                                                                                          :jobDir ""
                                                                                          :masterConfig {}
                                                                                          :masterType ""
                                                                                          :network ""
                                                                                          :packageUris []
                                                                                          :parameterServerConfig {}
                                                                                          :parameterServerCount ""
                                                                                          :parameterServerType ""
                                                                                          :pythonModule ""
                                                                                          :pythonVersion ""
                                                                                          :region ""
                                                                                          :runtimeVersion ""
                                                                                          :scaleTier ""
                                                                                          :scheduling {:maxRunningTime ""
                                                                                                       :maxWaitTime ""
                                                                                                       :priority 0}
                                                                                          :serviceAccount ""
                                                                                          :useChiefInTfConfig false
                                                                                          :workerConfig {}
                                                                                          :workerCount ""
                                                                                          :workerType ""}
                                                                          :trainingOutput {:builtInAlgorithmOutput {:framework ""
                                                                                                                    :modelPath ""
                                                                                                                    :pythonVersion ""
                                                                                                                    :runtimeVersion ""}
                                                                                           :completedTrialCount ""
                                                                                           :consumedMLUnits ""
                                                                                           :hyperparameterMetricTag ""
                                                                                           :isBuiltInAlgorithmJob false
                                                                                           :isHyperparameterTuningJob false
                                                                                           :trials [{:allMetrics [{:objectiveValue ""
                                                                                                                   :trainingStep ""}]
                                                                                                     :builtInAlgorithmOutput {}
                                                                                                     :endTime ""
                                                                                                     :finalMetric {}
                                                                                                     :hyperparameters {}
                                                                                                     :isTrialStoppedEarly false
                                                                                                     :startTime ""
                                                                                                     :state ""
                                                                                                     :trialId ""
                                                                                                     :webAccessUris {}}]
                                                                                           :webAccessUris {}}}})
require "http/client"

url = "{{baseUrl}}/v1/:parent/jobs"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:parent/jobs"),
    Content = new StringContent("{\n  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:parent/jobs");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v1/:parent/jobs HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2884

{
  "createTime": "",
  "endTime": "",
  "errorMessage": "",
  "etag": "",
  "jobId": "",
  "jobPosition": "",
  "labels": {},
  "predictionInput": {
    "batchSize": "",
    "dataFormat": "",
    "inputPaths": [],
    "maxWorkerCount": "",
    "modelName": "",
    "outputDataFormat": "",
    "outputPath": "",
    "region": "",
    "runtimeVersion": "",
    "signatureName": "",
    "uri": "",
    "versionName": ""
  },
  "predictionOutput": {
    "errorCount": "",
    "nodeHours": "",
    "outputPath": "",
    "predictionCount": ""
  },
  "startTime": "",
  "state": "",
  "trainingInput": {
    "args": [],
    "enableWebAccess": false,
    "encryptionConfig": {
      "kmsKeyName": ""
    },
    "evaluatorConfig": {
      "acceleratorConfig": {
        "count": "",
        "type": ""
      },
      "containerArgs": [],
      "containerCommand": [],
      "diskConfig": {
        "bootDiskSizeGb": 0,
        "bootDiskType": ""
      },
      "imageUri": "",
      "tpuTfVersion": ""
    },
    "evaluatorCount": "",
    "evaluatorType": "",
    "hyperparameters": {
      "algorithm": "",
      "enableTrialEarlyStopping": false,
      "goal": "",
      "hyperparameterMetricTag": "",
      "maxFailedTrials": 0,
      "maxParallelTrials": 0,
      "maxTrials": 0,
      "params": [
        {
          "categoricalValues": [],
          "discreteValues": [],
          "maxValue": "",
          "minValue": "",
          "parameterName": "",
          "scaleType": "",
          "type": ""
        }
      ],
      "resumePreviousJobId": ""
    },
    "jobDir": "",
    "masterConfig": {},
    "masterType": "",
    "network": "",
    "packageUris": [],
    "parameterServerConfig": {},
    "parameterServerCount": "",
    "parameterServerType": "",
    "pythonModule": "",
    "pythonVersion": "",
    "region": "",
    "runtimeVersion": "",
    "scaleTier": "",
    "scheduling": {
      "maxRunningTime": "",
      "maxWaitTime": "",
      "priority": 0
    },
    "serviceAccount": "",
    "useChiefInTfConfig": false,
    "workerConfig": {},
    "workerCount": "",
    "workerType": ""
  },
  "trainingOutput": {
    "builtInAlgorithmOutput": {
      "framework": "",
      "modelPath": "",
      "pythonVersion": "",
      "runtimeVersion": ""
    },
    "completedTrialCount": "",
    "consumedMLUnits": "",
    "hyperparameterMetricTag": "",
    "isBuiltInAlgorithmJob": false,
    "isHyperparameterTuningJob": false,
    "trials": [
      {
        "allMetrics": [
          {
            "objectiveValue": "",
            "trainingStep": ""
          }
        ],
        "builtInAlgorithmOutput": {},
        "endTime": "",
        "finalMetric": {},
        "hyperparameters": {},
        "isTrialStoppedEarly": false,
        "startTime": "",
        "state": "",
        "trialId": "",
        "webAccessUris": {}
      }
    ],
    "webAccessUris": {}
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:parent/jobs")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:parent/jobs"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\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  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:parent/jobs")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:parent/jobs")
  .header("content-type", "application/json")
  .body("{\n  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}")
  .asString();
const data = JSON.stringify({
  createTime: '',
  endTime: '',
  errorMessage: '',
  etag: '',
  jobId: '',
  jobPosition: '',
  labels: {},
  predictionInput: {
    batchSize: '',
    dataFormat: '',
    inputPaths: [],
    maxWorkerCount: '',
    modelName: '',
    outputDataFormat: '',
    outputPath: '',
    region: '',
    runtimeVersion: '',
    signatureName: '',
    uri: '',
    versionName: ''
  },
  predictionOutput: {
    errorCount: '',
    nodeHours: '',
    outputPath: '',
    predictionCount: ''
  },
  startTime: '',
  state: '',
  trainingInput: {
    args: [],
    enableWebAccess: false,
    encryptionConfig: {
      kmsKeyName: ''
    },
    evaluatorConfig: {
      acceleratorConfig: {
        count: '',
        type: ''
      },
      containerArgs: [],
      containerCommand: [],
      diskConfig: {
        bootDiskSizeGb: 0,
        bootDiskType: ''
      },
      imageUri: '',
      tpuTfVersion: ''
    },
    evaluatorCount: '',
    evaluatorType: '',
    hyperparameters: {
      algorithm: '',
      enableTrialEarlyStopping: false,
      goal: '',
      hyperparameterMetricTag: '',
      maxFailedTrials: 0,
      maxParallelTrials: 0,
      maxTrials: 0,
      params: [
        {
          categoricalValues: [],
          discreteValues: [],
          maxValue: '',
          minValue: '',
          parameterName: '',
          scaleType: '',
          type: ''
        }
      ],
      resumePreviousJobId: ''
    },
    jobDir: '',
    masterConfig: {},
    masterType: '',
    network: '',
    packageUris: [],
    parameterServerConfig: {},
    parameterServerCount: '',
    parameterServerType: '',
    pythonModule: '',
    pythonVersion: '',
    region: '',
    runtimeVersion: '',
    scaleTier: '',
    scheduling: {
      maxRunningTime: '',
      maxWaitTime: '',
      priority: 0
    },
    serviceAccount: '',
    useChiefInTfConfig: false,
    workerConfig: {},
    workerCount: '',
    workerType: ''
  },
  trainingOutput: {
    builtInAlgorithmOutput: {
      framework: '',
      modelPath: '',
      pythonVersion: '',
      runtimeVersion: ''
    },
    completedTrialCount: '',
    consumedMLUnits: '',
    hyperparameterMetricTag: '',
    isBuiltInAlgorithmJob: false,
    isHyperparameterTuningJob: false,
    trials: [
      {
        allMetrics: [
          {
            objectiveValue: '',
            trainingStep: ''
          }
        ],
        builtInAlgorithmOutput: {},
        endTime: '',
        finalMetric: {},
        hyperparameters: {},
        isTrialStoppedEarly: false,
        startTime: '',
        state: '',
        trialId: '',
        webAccessUris: {}
      }
    ],
    webAccessUris: {}
  }
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/jobs',
  headers: {'content-type': 'application/json'},
  data: {
    createTime: '',
    endTime: '',
    errorMessage: '',
    etag: '',
    jobId: '',
    jobPosition: '',
    labels: {},
    predictionInput: {
      batchSize: '',
      dataFormat: '',
      inputPaths: [],
      maxWorkerCount: '',
      modelName: '',
      outputDataFormat: '',
      outputPath: '',
      region: '',
      runtimeVersion: '',
      signatureName: '',
      uri: '',
      versionName: ''
    },
    predictionOutput: {errorCount: '', nodeHours: '', outputPath: '', predictionCount: ''},
    startTime: '',
    state: '',
    trainingInput: {
      args: [],
      enableWebAccess: false,
      encryptionConfig: {kmsKeyName: ''},
      evaluatorConfig: {
        acceleratorConfig: {count: '', type: ''},
        containerArgs: [],
        containerCommand: [],
        diskConfig: {bootDiskSizeGb: 0, bootDiskType: ''},
        imageUri: '',
        tpuTfVersion: ''
      },
      evaluatorCount: '',
      evaluatorType: '',
      hyperparameters: {
        algorithm: '',
        enableTrialEarlyStopping: false,
        goal: '',
        hyperparameterMetricTag: '',
        maxFailedTrials: 0,
        maxParallelTrials: 0,
        maxTrials: 0,
        params: [
          {
            categoricalValues: [],
            discreteValues: [],
            maxValue: '',
            minValue: '',
            parameterName: '',
            scaleType: '',
            type: ''
          }
        ],
        resumePreviousJobId: ''
      },
      jobDir: '',
      masterConfig: {},
      masterType: '',
      network: '',
      packageUris: [],
      parameterServerConfig: {},
      parameterServerCount: '',
      parameterServerType: '',
      pythonModule: '',
      pythonVersion: '',
      region: '',
      runtimeVersion: '',
      scaleTier: '',
      scheduling: {maxRunningTime: '', maxWaitTime: '', priority: 0},
      serviceAccount: '',
      useChiefInTfConfig: false,
      workerConfig: {},
      workerCount: '',
      workerType: ''
    },
    trainingOutput: {
      builtInAlgorithmOutput: {framework: '', modelPath: '', pythonVersion: '', runtimeVersion: ''},
      completedTrialCount: '',
      consumedMLUnits: '',
      hyperparameterMetricTag: '',
      isBuiltInAlgorithmJob: false,
      isHyperparameterTuningJob: false,
      trials: [
        {
          allMetrics: [{objectiveValue: '', trainingStep: ''}],
          builtInAlgorithmOutput: {},
          endTime: '',
          finalMetric: {},
          hyperparameters: {},
          isTrialStoppedEarly: false,
          startTime: '',
          state: '',
          trialId: '',
          webAccessUris: {}
        }
      ],
      webAccessUris: {}
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:parent/jobs';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"createTime":"","endTime":"","errorMessage":"","etag":"","jobId":"","jobPosition":"","labels":{},"predictionInput":{"batchSize":"","dataFormat":"","inputPaths":[],"maxWorkerCount":"","modelName":"","outputDataFormat":"","outputPath":"","region":"","runtimeVersion":"","signatureName":"","uri":"","versionName":""},"predictionOutput":{"errorCount":"","nodeHours":"","outputPath":"","predictionCount":""},"startTime":"","state":"","trainingInput":{"args":[],"enableWebAccess":false,"encryptionConfig":{"kmsKeyName":""},"evaluatorConfig":{"acceleratorConfig":{"count":"","type":""},"containerArgs":[],"containerCommand":[],"diskConfig":{"bootDiskSizeGb":0,"bootDiskType":""},"imageUri":"","tpuTfVersion":""},"evaluatorCount":"","evaluatorType":"","hyperparameters":{"algorithm":"","enableTrialEarlyStopping":false,"goal":"","hyperparameterMetricTag":"","maxFailedTrials":0,"maxParallelTrials":0,"maxTrials":0,"params":[{"categoricalValues":[],"discreteValues":[],"maxValue":"","minValue":"","parameterName":"","scaleType":"","type":""}],"resumePreviousJobId":""},"jobDir":"","masterConfig":{},"masterType":"","network":"","packageUris":[],"parameterServerConfig":{},"parameterServerCount":"","parameterServerType":"","pythonModule":"","pythonVersion":"","region":"","runtimeVersion":"","scaleTier":"","scheduling":{"maxRunningTime":"","maxWaitTime":"","priority":0},"serviceAccount":"","useChiefInTfConfig":false,"workerConfig":{},"workerCount":"","workerType":""},"trainingOutput":{"builtInAlgorithmOutput":{"framework":"","modelPath":"","pythonVersion":"","runtimeVersion":""},"completedTrialCount":"","consumedMLUnits":"","hyperparameterMetricTag":"","isBuiltInAlgorithmJob":false,"isHyperparameterTuningJob":false,"trials":[{"allMetrics":[{"objectiveValue":"","trainingStep":""}],"builtInAlgorithmOutput":{},"endTime":"","finalMetric":{},"hyperparameters":{},"isTrialStoppedEarly":false,"startTime":"","state":"","trialId":"","webAccessUris":{}}],"webAccessUris":{}}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:parent/jobs',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "createTime": "",\n  "endTime": "",\n  "errorMessage": "",\n  "etag": "",\n  "jobId": "",\n  "jobPosition": "",\n  "labels": {},\n  "predictionInput": {\n    "batchSize": "",\n    "dataFormat": "",\n    "inputPaths": [],\n    "maxWorkerCount": "",\n    "modelName": "",\n    "outputDataFormat": "",\n    "outputPath": "",\n    "region": "",\n    "runtimeVersion": "",\n    "signatureName": "",\n    "uri": "",\n    "versionName": ""\n  },\n  "predictionOutput": {\n    "errorCount": "",\n    "nodeHours": "",\n    "outputPath": "",\n    "predictionCount": ""\n  },\n  "startTime": "",\n  "state": "",\n  "trainingInput": {\n    "args": [],\n    "enableWebAccess": false,\n    "encryptionConfig": {\n      "kmsKeyName": ""\n    },\n    "evaluatorConfig": {\n      "acceleratorConfig": {\n        "count": "",\n        "type": ""\n      },\n      "containerArgs": [],\n      "containerCommand": [],\n      "diskConfig": {\n        "bootDiskSizeGb": 0,\n        "bootDiskType": ""\n      },\n      "imageUri": "",\n      "tpuTfVersion": ""\n    },\n    "evaluatorCount": "",\n    "evaluatorType": "",\n    "hyperparameters": {\n      "algorithm": "",\n      "enableTrialEarlyStopping": false,\n      "goal": "",\n      "hyperparameterMetricTag": "",\n      "maxFailedTrials": 0,\n      "maxParallelTrials": 0,\n      "maxTrials": 0,\n      "params": [\n        {\n          "categoricalValues": [],\n          "discreteValues": [],\n          "maxValue": "",\n          "minValue": "",\n          "parameterName": "",\n          "scaleType": "",\n          "type": ""\n        }\n      ],\n      "resumePreviousJobId": ""\n    },\n    "jobDir": "",\n    "masterConfig": {},\n    "masterType": "",\n    "network": "",\n    "packageUris": [],\n    "parameterServerConfig": {},\n    "parameterServerCount": "",\n    "parameterServerType": "",\n    "pythonModule": "",\n    "pythonVersion": "",\n    "region": "",\n    "runtimeVersion": "",\n    "scaleTier": "",\n    "scheduling": {\n      "maxRunningTime": "",\n      "maxWaitTime": "",\n      "priority": 0\n    },\n    "serviceAccount": "",\n    "useChiefInTfConfig": false,\n    "workerConfig": {},\n    "workerCount": "",\n    "workerType": ""\n  },\n  "trainingOutput": {\n    "builtInAlgorithmOutput": {\n      "framework": "",\n      "modelPath": "",\n      "pythonVersion": "",\n      "runtimeVersion": ""\n    },\n    "completedTrialCount": "",\n    "consumedMLUnits": "",\n    "hyperparameterMetricTag": "",\n    "isBuiltInAlgorithmJob": false,\n    "isHyperparameterTuningJob": false,\n    "trials": [\n      {\n        "allMetrics": [\n          {\n            "objectiveValue": "",\n            "trainingStep": ""\n          }\n        ],\n        "builtInAlgorithmOutput": {},\n        "endTime": "",\n        "finalMetric": {},\n        "hyperparameters": {},\n        "isTrialStoppedEarly": false,\n        "startTime": "",\n        "state": "",\n        "trialId": "",\n        "webAccessUris": {}\n      }\n    ],\n    "webAccessUris": {}\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  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/: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/v1/: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({
  createTime: '',
  endTime: '',
  errorMessage: '',
  etag: '',
  jobId: '',
  jobPosition: '',
  labels: {},
  predictionInput: {
    batchSize: '',
    dataFormat: '',
    inputPaths: [],
    maxWorkerCount: '',
    modelName: '',
    outputDataFormat: '',
    outputPath: '',
    region: '',
    runtimeVersion: '',
    signatureName: '',
    uri: '',
    versionName: ''
  },
  predictionOutput: {errorCount: '', nodeHours: '', outputPath: '', predictionCount: ''},
  startTime: '',
  state: '',
  trainingInput: {
    args: [],
    enableWebAccess: false,
    encryptionConfig: {kmsKeyName: ''},
    evaluatorConfig: {
      acceleratorConfig: {count: '', type: ''},
      containerArgs: [],
      containerCommand: [],
      diskConfig: {bootDiskSizeGb: 0, bootDiskType: ''},
      imageUri: '',
      tpuTfVersion: ''
    },
    evaluatorCount: '',
    evaluatorType: '',
    hyperparameters: {
      algorithm: '',
      enableTrialEarlyStopping: false,
      goal: '',
      hyperparameterMetricTag: '',
      maxFailedTrials: 0,
      maxParallelTrials: 0,
      maxTrials: 0,
      params: [
        {
          categoricalValues: [],
          discreteValues: [],
          maxValue: '',
          minValue: '',
          parameterName: '',
          scaleType: '',
          type: ''
        }
      ],
      resumePreviousJobId: ''
    },
    jobDir: '',
    masterConfig: {},
    masterType: '',
    network: '',
    packageUris: [],
    parameterServerConfig: {},
    parameterServerCount: '',
    parameterServerType: '',
    pythonModule: '',
    pythonVersion: '',
    region: '',
    runtimeVersion: '',
    scaleTier: '',
    scheduling: {maxRunningTime: '', maxWaitTime: '', priority: 0},
    serviceAccount: '',
    useChiefInTfConfig: false,
    workerConfig: {},
    workerCount: '',
    workerType: ''
  },
  trainingOutput: {
    builtInAlgorithmOutput: {framework: '', modelPath: '', pythonVersion: '', runtimeVersion: ''},
    completedTrialCount: '',
    consumedMLUnits: '',
    hyperparameterMetricTag: '',
    isBuiltInAlgorithmJob: false,
    isHyperparameterTuningJob: false,
    trials: [
      {
        allMetrics: [{objectiveValue: '', trainingStep: ''}],
        builtInAlgorithmOutput: {},
        endTime: '',
        finalMetric: {},
        hyperparameters: {},
        isTrialStoppedEarly: false,
        startTime: '',
        state: '',
        trialId: '',
        webAccessUris: {}
      }
    ],
    webAccessUris: {}
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/jobs',
  headers: {'content-type': 'application/json'},
  body: {
    createTime: '',
    endTime: '',
    errorMessage: '',
    etag: '',
    jobId: '',
    jobPosition: '',
    labels: {},
    predictionInput: {
      batchSize: '',
      dataFormat: '',
      inputPaths: [],
      maxWorkerCount: '',
      modelName: '',
      outputDataFormat: '',
      outputPath: '',
      region: '',
      runtimeVersion: '',
      signatureName: '',
      uri: '',
      versionName: ''
    },
    predictionOutput: {errorCount: '', nodeHours: '', outputPath: '', predictionCount: ''},
    startTime: '',
    state: '',
    trainingInput: {
      args: [],
      enableWebAccess: false,
      encryptionConfig: {kmsKeyName: ''},
      evaluatorConfig: {
        acceleratorConfig: {count: '', type: ''},
        containerArgs: [],
        containerCommand: [],
        diskConfig: {bootDiskSizeGb: 0, bootDiskType: ''},
        imageUri: '',
        tpuTfVersion: ''
      },
      evaluatorCount: '',
      evaluatorType: '',
      hyperparameters: {
        algorithm: '',
        enableTrialEarlyStopping: false,
        goal: '',
        hyperparameterMetricTag: '',
        maxFailedTrials: 0,
        maxParallelTrials: 0,
        maxTrials: 0,
        params: [
          {
            categoricalValues: [],
            discreteValues: [],
            maxValue: '',
            minValue: '',
            parameterName: '',
            scaleType: '',
            type: ''
          }
        ],
        resumePreviousJobId: ''
      },
      jobDir: '',
      masterConfig: {},
      masterType: '',
      network: '',
      packageUris: [],
      parameterServerConfig: {},
      parameterServerCount: '',
      parameterServerType: '',
      pythonModule: '',
      pythonVersion: '',
      region: '',
      runtimeVersion: '',
      scaleTier: '',
      scheduling: {maxRunningTime: '', maxWaitTime: '', priority: 0},
      serviceAccount: '',
      useChiefInTfConfig: false,
      workerConfig: {},
      workerCount: '',
      workerType: ''
    },
    trainingOutput: {
      builtInAlgorithmOutput: {framework: '', modelPath: '', pythonVersion: '', runtimeVersion: ''},
      completedTrialCount: '',
      consumedMLUnits: '',
      hyperparameterMetricTag: '',
      isBuiltInAlgorithmJob: false,
      isHyperparameterTuningJob: false,
      trials: [
        {
          allMetrics: [{objectiveValue: '', trainingStep: ''}],
          builtInAlgorithmOutput: {},
          endTime: '',
          finalMetric: {},
          hyperparameters: {},
          isTrialStoppedEarly: false,
          startTime: '',
          state: '',
          trialId: '',
          webAccessUris: {}
        }
      ],
      webAccessUris: {}
    }
  },
  json: true
};

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

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

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

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

req.type('json');
req.send({
  createTime: '',
  endTime: '',
  errorMessage: '',
  etag: '',
  jobId: '',
  jobPosition: '',
  labels: {},
  predictionInput: {
    batchSize: '',
    dataFormat: '',
    inputPaths: [],
    maxWorkerCount: '',
    modelName: '',
    outputDataFormat: '',
    outputPath: '',
    region: '',
    runtimeVersion: '',
    signatureName: '',
    uri: '',
    versionName: ''
  },
  predictionOutput: {
    errorCount: '',
    nodeHours: '',
    outputPath: '',
    predictionCount: ''
  },
  startTime: '',
  state: '',
  trainingInput: {
    args: [],
    enableWebAccess: false,
    encryptionConfig: {
      kmsKeyName: ''
    },
    evaluatorConfig: {
      acceleratorConfig: {
        count: '',
        type: ''
      },
      containerArgs: [],
      containerCommand: [],
      diskConfig: {
        bootDiskSizeGb: 0,
        bootDiskType: ''
      },
      imageUri: '',
      tpuTfVersion: ''
    },
    evaluatorCount: '',
    evaluatorType: '',
    hyperparameters: {
      algorithm: '',
      enableTrialEarlyStopping: false,
      goal: '',
      hyperparameterMetricTag: '',
      maxFailedTrials: 0,
      maxParallelTrials: 0,
      maxTrials: 0,
      params: [
        {
          categoricalValues: [],
          discreteValues: [],
          maxValue: '',
          minValue: '',
          parameterName: '',
          scaleType: '',
          type: ''
        }
      ],
      resumePreviousJobId: ''
    },
    jobDir: '',
    masterConfig: {},
    masterType: '',
    network: '',
    packageUris: [],
    parameterServerConfig: {},
    parameterServerCount: '',
    parameterServerType: '',
    pythonModule: '',
    pythonVersion: '',
    region: '',
    runtimeVersion: '',
    scaleTier: '',
    scheduling: {
      maxRunningTime: '',
      maxWaitTime: '',
      priority: 0
    },
    serviceAccount: '',
    useChiefInTfConfig: false,
    workerConfig: {},
    workerCount: '',
    workerType: ''
  },
  trainingOutput: {
    builtInAlgorithmOutput: {
      framework: '',
      modelPath: '',
      pythonVersion: '',
      runtimeVersion: ''
    },
    completedTrialCount: '',
    consumedMLUnits: '',
    hyperparameterMetricTag: '',
    isBuiltInAlgorithmJob: false,
    isHyperparameterTuningJob: false,
    trials: [
      {
        allMetrics: [
          {
            objectiveValue: '',
            trainingStep: ''
          }
        ],
        builtInAlgorithmOutput: {},
        endTime: '',
        finalMetric: {},
        hyperparameters: {},
        isTrialStoppedEarly: false,
        startTime: '',
        state: '',
        trialId: '',
        webAccessUris: {}
      }
    ],
    webAccessUris: {}
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/jobs',
  headers: {'content-type': 'application/json'},
  data: {
    createTime: '',
    endTime: '',
    errorMessage: '',
    etag: '',
    jobId: '',
    jobPosition: '',
    labels: {},
    predictionInput: {
      batchSize: '',
      dataFormat: '',
      inputPaths: [],
      maxWorkerCount: '',
      modelName: '',
      outputDataFormat: '',
      outputPath: '',
      region: '',
      runtimeVersion: '',
      signatureName: '',
      uri: '',
      versionName: ''
    },
    predictionOutput: {errorCount: '', nodeHours: '', outputPath: '', predictionCount: ''},
    startTime: '',
    state: '',
    trainingInput: {
      args: [],
      enableWebAccess: false,
      encryptionConfig: {kmsKeyName: ''},
      evaluatorConfig: {
        acceleratorConfig: {count: '', type: ''},
        containerArgs: [],
        containerCommand: [],
        diskConfig: {bootDiskSizeGb: 0, bootDiskType: ''},
        imageUri: '',
        tpuTfVersion: ''
      },
      evaluatorCount: '',
      evaluatorType: '',
      hyperparameters: {
        algorithm: '',
        enableTrialEarlyStopping: false,
        goal: '',
        hyperparameterMetricTag: '',
        maxFailedTrials: 0,
        maxParallelTrials: 0,
        maxTrials: 0,
        params: [
          {
            categoricalValues: [],
            discreteValues: [],
            maxValue: '',
            minValue: '',
            parameterName: '',
            scaleType: '',
            type: ''
          }
        ],
        resumePreviousJobId: ''
      },
      jobDir: '',
      masterConfig: {},
      masterType: '',
      network: '',
      packageUris: [],
      parameterServerConfig: {},
      parameterServerCount: '',
      parameterServerType: '',
      pythonModule: '',
      pythonVersion: '',
      region: '',
      runtimeVersion: '',
      scaleTier: '',
      scheduling: {maxRunningTime: '', maxWaitTime: '', priority: 0},
      serviceAccount: '',
      useChiefInTfConfig: false,
      workerConfig: {},
      workerCount: '',
      workerType: ''
    },
    trainingOutput: {
      builtInAlgorithmOutput: {framework: '', modelPath: '', pythonVersion: '', runtimeVersion: ''},
      completedTrialCount: '',
      consumedMLUnits: '',
      hyperparameterMetricTag: '',
      isBuiltInAlgorithmJob: false,
      isHyperparameterTuningJob: false,
      trials: [
        {
          allMetrics: [{objectiveValue: '', trainingStep: ''}],
          builtInAlgorithmOutput: {},
          endTime: '',
          finalMetric: {},
          hyperparameters: {},
          isTrialStoppedEarly: false,
          startTime: '',
          state: '',
          trialId: '',
          webAccessUris: {}
        }
      ],
      webAccessUris: {}
    }
  }
};

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

const url = '{{baseUrl}}/v1/:parent/jobs';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"createTime":"","endTime":"","errorMessage":"","etag":"","jobId":"","jobPosition":"","labels":{},"predictionInput":{"batchSize":"","dataFormat":"","inputPaths":[],"maxWorkerCount":"","modelName":"","outputDataFormat":"","outputPath":"","region":"","runtimeVersion":"","signatureName":"","uri":"","versionName":""},"predictionOutput":{"errorCount":"","nodeHours":"","outputPath":"","predictionCount":""},"startTime":"","state":"","trainingInput":{"args":[],"enableWebAccess":false,"encryptionConfig":{"kmsKeyName":""},"evaluatorConfig":{"acceleratorConfig":{"count":"","type":""},"containerArgs":[],"containerCommand":[],"diskConfig":{"bootDiskSizeGb":0,"bootDiskType":""},"imageUri":"","tpuTfVersion":""},"evaluatorCount":"","evaluatorType":"","hyperparameters":{"algorithm":"","enableTrialEarlyStopping":false,"goal":"","hyperparameterMetricTag":"","maxFailedTrials":0,"maxParallelTrials":0,"maxTrials":0,"params":[{"categoricalValues":[],"discreteValues":[],"maxValue":"","minValue":"","parameterName":"","scaleType":"","type":""}],"resumePreviousJobId":""},"jobDir":"","masterConfig":{},"masterType":"","network":"","packageUris":[],"parameterServerConfig":{},"parameterServerCount":"","parameterServerType":"","pythonModule":"","pythonVersion":"","region":"","runtimeVersion":"","scaleTier":"","scheduling":{"maxRunningTime":"","maxWaitTime":"","priority":0},"serviceAccount":"","useChiefInTfConfig":false,"workerConfig":{},"workerCount":"","workerType":""},"trainingOutput":{"builtInAlgorithmOutput":{"framework":"","modelPath":"","pythonVersion":"","runtimeVersion":""},"completedTrialCount":"","consumedMLUnits":"","hyperparameterMetricTag":"","isBuiltInAlgorithmJob":false,"isHyperparameterTuningJob":false,"trials":[{"allMetrics":[{"objectiveValue":"","trainingStep":""}],"builtInAlgorithmOutput":{},"endTime":"","finalMetric":{},"hyperparameters":{},"isTrialStoppedEarly":false,"startTime":"","state":"","trialId":"","webAccessUris":{}}],"webAccessUris":{}}}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"createTime": @"",
                              @"endTime": @"",
                              @"errorMessage": @"",
                              @"etag": @"",
                              @"jobId": @"",
                              @"jobPosition": @"",
                              @"labels": @{  },
                              @"predictionInput": @{ @"batchSize": @"", @"dataFormat": @"", @"inputPaths": @[  ], @"maxWorkerCount": @"", @"modelName": @"", @"outputDataFormat": @"", @"outputPath": @"", @"region": @"", @"runtimeVersion": @"", @"signatureName": @"", @"uri": @"", @"versionName": @"" },
                              @"predictionOutput": @{ @"errorCount": @"", @"nodeHours": @"", @"outputPath": @"", @"predictionCount": @"" },
                              @"startTime": @"",
                              @"state": @"",
                              @"trainingInput": @{ @"args": @[  ], @"enableWebAccess": @NO, @"encryptionConfig": @{ @"kmsKeyName": @"" }, @"evaluatorConfig": @{ @"acceleratorConfig": @{ @"count": @"", @"type": @"" }, @"containerArgs": @[  ], @"containerCommand": @[  ], @"diskConfig": @{ @"bootDiskSizeGb": @0, @"bootDiskType": @"" }, @"imageUri": @"", @"tpuTfVersion": @"" }, @"evaluatorCount": @"", @"evaluatorType": @"", @"hyperparameters": @{ @"algorithm": @"", @"enableTrialEarlyStopping": @NO, @"goal": @"", @"hyperparameterMetricTag": @"", @"maxFailedTrials": @0, @"maxParallelTrials": @0, @"maxTrials": @0, @"params": @[ @{ @"categoricalValues": @[  ], @"discreteValues": @[  ], @"maxValue": @"", @"minValue": @"", @"parameterName": @"", @"scaleType": @"", @"type": @"" } ], @"resumePreviousJobId": @"" }, @"jobDir": @"", @"masterConfig": @{  }, @"masterType": @"", @"network": @"", @"packageUris": @[  ], @"parameterServerConfig": @{  }, @"parameterServerCount": @"", @"parameterServerType": @"", @"pythonModule": @"", @"pythonVersion": @"", @"region": @"", @"runtimeVersion": @"", @"scaleTier": @"", @"scheduling": @{ @"maxRunningTime": @"", @"maxWaitTime": @"", @"priority": @0 }, @"serviceAccount": @"", @"useChiefInTfConfig": @NO, @"workerConfig": @{  }, @"workerCount": @"", @"workerType": @"" },
                              @"trainingOutput": @{ @"builtInAlgorithmOutput": @{ @"framework": @"", @"modelPath": @"", @"pythonVersion": @"", @"runtimeVersion": @"" }, @"completedTrialCount": @"", @"consumedMLUnits": @"", @"hyperparameterMetricTag": @"", @"isBuiltInAlgorithmJob": @NO, @"isHyperparameterTuningJob": @NO, @"trials": @[ @{ @"allMetrics": @[ @{ @"objectiveValue": @"", @"trainingStep": @"" } ], @"builtInAlgorithmOutput": @{  }, @"endTime": @"", @"finalMetric": @{  }, @"hyperparameters": @{  }, @"isTrialStoppedEarly": @NO, @"startTime": @"", @"state": @"", @"trialId": @"", @"webAccessUris": @{  } } ], @"webAccessUris": @{  } } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/: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}}/v1/:parent/jobs" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/: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([
    'createTime' => '',
    'endTime' => '',
    'errorMessage' => '',
    'etag' => '',
    'jobId' => '',
    'jobPosition' => '',
    'labels' => [
        
    ],
    'predictionInput' => [
        'batchSize' => '',
        'dataFormat' => '',
        'inputPaths' => [
                
        ],
        'maxWorkerCount' => '',
        'modelName' => '',
        'outputDataFormat' => '',
        'outputPath' => '',
        'region' => '',
        'runtimeVersion' => '',
        'signatureName' => '',
        'uri' => '',
        'versionName' => ''
    ],
    'predictionOutput' => [
        'errorCount' => '',
        'nodeHours' => '',
        'outputPath' => '',
        'predictionCount' => ''
    ],
    'startTime' => '',
    'state' => '',
    'trainingInput' => [
        'args' => [
                
        ],
        'enableWebAccess' => null,
        'encryptionConfig' => [
                'kmsKeyName' => ''
        ],
        'evaluatorConfig' => [
                'acceleratorConfig' => [
                                'count' => '',
                                'type' => ''
                ],
                'containerArgs' => [
                                
                ],
                'containerCommand' => [
                                
                ],
                'diskConfig' => [
                                'bootDiskSizeGb' => 0,
                                'bootDiskType' => ''
                ],
                'imageUri' => '',
                'tpuTfVersion' => ''
        ],
        'evaluatorCount' => '',
        'evaluatorType' => '',
        'hyperparameters' => [
                'algorithm' => '',
                'enableTrialEarlyStopping' => null,
                'goal' => '',
                'hyperparameterMetricTag' => '',
                'maxFailedTrials' => 0,
                'maxParallelTrials' => 0,
                'maxTrials' => 0,
                'params' => [
                                [
                                                                'categoricalValues' => [
                                                                                                                                
                                                                ],
                                                                'discreteValues' => [
                                                                                                                                
                                                                ],
                                                                'maxValue' => '',
                                                                'minValue' => '',
                                                                'parameterName' => '',
                                                                'scaleType' => '',
                                                                'type' => ''
                                ]
                ],
                'resumePreviousJobId' => ''
        ],
        'jobDir' => '',
        'masterConfig' => [
                
        ],
        'masterType' => '',
        'network' => '',
        'packageUris' => [
                
        ],
        'parameterServerConfig' => [
                
        ],
        'parameterServerCount' => '',
        'parameterServerType' => '',
        'pythonModule' => '',
        'pythonVersion' => '',
        'region' => '',
        'runtimeVersion' => '',
        'scaleTier' => '',
        'scheduling' => [
                'maxRunningTime' => '',
                'maxWaitTime' => '',
                'priority' => 0
        ],
        'serviceAccount' => '',
        'useChiefInTfConfig' => null,
        'workerConfig' => [
                
        ],
        'workerCount' => '',
        'workerType' => ''
    ],
    'trainingOutput' => [
        'builtInAlgorithmOutput' => [
                'framework' => '',
                'modelPath' => '',
                'pythonVersion' => '',
                'runtimeVersion' => ''
        ],
        'completedTrialCount' => '',
        'consumedMLUnits' => '',
        'hyperparameterMetricTag' => '',
        'isBuiltInAlgorithmJob' => null,
        'isHyperparameterTuningJob' => null,
        'trials' => [
                [
                                'allMetrics' => [
                                                                [
                                                                                                                                'objectiveValue' => '',
                                                                                                                                'trainingStep' => ''
                                                                ]
                                ],
                                'builtInAlgorithmOutput' => [
                                                                
                                ],
                                'endTime' => '',
                                'finalMetric' => [
                                                                
                                ],
                                'hyperparameters' => [
                                                                
                                ],
                                'isTrialStoppedEarly' => null,
                                'startTime' => '',
                                'state' => '',
                                'trialId' => '',
                                'webAccessUris' => [
                                                                
                                ]
                ]
        ],
        'webAccessUris' => [
                
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:parent/jobs', [
  'body' => '{
  "createTime": "",
  "endTime": "",
  "errorMessage": "",
  "etag": "",
  "jobId": "",
  "jobPosition": "",
  "labels": {},
  "predictionInput": {
    "batchSize": "",
    "dataFormat": "",
    "inputPaths": [],
    "maxWorkerCount": "",
    "modelName": "",
    "outputDataFormat": "",
    "outputPath": "",
    "region": "",
    "runtimeVersion": "",
    "signatureName": "",
    "uri": "",
    "versionName": ""
  },
  "predictionOutput": {
    "errorCount": "",
    "nodeHours": "",
    "outputPath": "",
    "predictionCount": ""
  },
  "startTime": "",
  "state": "",
  "trainingInput": {
    "args": [],
    "enableWebAccess": false,
    "encryptionConfig": {
      "kmsKeyName": ""
    },
    "evaluatorConfig": {
      "acceleratorConfig": {
        "count": "",
        "type": ""
      },
      "containerArgs": [],
      "containerCommand": [],
      "diskConfig": {
        "bootDiskSizeGb": 0,
        "bootDiskType": ""
      },
      "imageUri": "",
      "tpuTfVersion": ""
    },
    "evaluatorCount": "",
    "evaluatorType": "",
    "hyperparameters": {
      "algorithm": "",
      "enableTrialEarlyStopping": false,
      "goal": "",
      "hyperparameterMetricTag": "",
      "maxFailedTrials": 0,
      "maxParallelTrials": 0,
      "maxTrials": 0,
      "params": [
        {
          "categoricalValues": [],
          "discreteValues": [],
          "maxValue": "",
          "minValue": "",
          "parameterName": "",
          "scaleType": "",
          "type": ""
        }
      ],
      "resumePreviousJobId": ""
    },
    "jobDir": "",
    "masterConfig": {},
    "masterType": "",
    "network": "",
    "packageUris": [],
    "parameterServerConfig": {},
    "parameterServerCount": "",
    "parameterServerType": "",
    "pythonModule": "",
    "pythonVersion": "",
    "region": "",
    "runtimeVersion": "",
    "scaleTier": "",
    "scheduling": {
      "maxRunningTime": "",
      "maxWaitTime": "",
      "priority": 0
    },
    "serviceAccount": "",
    "useChiefInTfConfig": false,
    "workerConfig": {},
    "workerCount": "",
    "workerType": ""
  },
  "trainingOutput": {
    "builtInAlgorithmOutput": {
      "framework": "",
      "modelPath": "",
      "pythonVersion": "",
      "runtimeVersion": ""
    },
    "completedTrialCount": "",
    "consumedMLUnits": "",
    "hyperparameterMetricTag": "",
    "isBuiltInAlgorithmJob": false,
    "isHyperparameterTuningJob": false,
    "trials": [
      {
        "allMetrics": [
          {
            "objectiveValue": "",
            "trainingStep": ""
          }
        ],
        "builtInAlgorithmOutput": {},
        "endTime": "",
        "finalMetric": {},
        "hyperparameters": {},
        "isTrialStoppedEarly": false,
        "startTime": "",
        "state": "",
        "trialId": "",
        "webAccessUris": {}
      }
    ],
    "webAccessUris": {}
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'createTime' => '',
  'endTime' => '',
  'errorMessage' => '',
  'etag' => '',
  'jobId' => '',
  'jobPosition' => '',
  'labels' => [
    
  ],
  'predictionInput' => [
    'batchSize' => '',
    'dataFormat' => '',
    'inputPaths' => [
        
    ],
    'maxWorkerCount' => '',
    'modelName' => '',
    'outputDataFormat' => '',
    'outputPath' => '',
    'region' => '',
    'runtimeVersion' => '',
    'signatureName' => '',
    'uri' => '',
    'versionName' => ''
  ],
  'predictionOutput' => [
    'errorCount' => '',
    'nodeHours' => '',
    'outputPath' => '',
    'predictionCount' => ''
  ],
  'startTime' => '',
  'state' => '',
  'trainingInput' => [
    'args' => [
        
    ],
    'enableWebAccess' => null,
    'encryptionConfig' => [
        'kmsKeyName' => ''
    ],
    'evaluatorConfig' => [
        'acceleratorConfig' => [
                'count' => '',
                'type' => ''
        ],
        'containerArgs' => [
                
        ],
        'containerCommand' => [
                
        ],
        'diskConfig' => [
                'bootDiskSizeGb' => 0,
                'bootDiskType' => ''
        ],
        'imageUri' => '',
        'tpuTfVersion' => ''
    ],
    'evaluatorCount' => '',
    'evaluatorType' => '',
    'hyperparameters' => [
        'algorithm' => '',
        'enableTrialEarlyStopping' => null,
        'goal' => '',
        'hyperparameterMetricTag' => '',
        'maxFailedTrials' => 0,
        'maxParallelTrials' => 0,
        'maxTrials' => 0,
        'params' => [
                [
                                'categoricalValues' => [
                                                                
                                ],
                                'discreteValues' => [
                                                                
                                ],
                                'maxValue' => '',
                                'minValue' => '',
                                'parameterName' => '',
                                'scaleType' => '',
                                'type' => ''
                ]
        ],
        'resumePreviousJobId' => ''
    ],
    'jobDir' => '',
    'masterConfig' => [
        
    ],
    'masterType' => '',
    'network' => '',
    'packageUris' => [
        
    ],
    'parameterServerConfig' => [
        
    ],
    'parameterServerCount' => '',
    'parameterServerType' => '',
    'pythonModule' => '',
    'pythonVersion' => '',
    'region' => '',
    'runtimeVersion' => '',
    'scaleTier' => '',
    'scheduling' => [
        'maxRunningTime' => '',
        'maxWaitTime' => '',
        'priority' => 0
    ],
    'serviceAccount' => '',
    'useChiefInTfConfig' => null,
    'workerConfig' => [
        
    ],
    'workerCount' => '',
    'workerType' => ''
  ],
  'trainingOutput' => [
    'builtInAlgorithmOutput' => [
        'framework' => '',
        'modelPath' => '',
        'pythonVersion' => '',
        'runtimeVersion' => ''
    ],
    'completedTrialCount' => '',
    'consumedMLUnits' => '',
    'hyperparameterMetricTag' => '',
    'isBuiltInAlgorithmJob' => null,
    'isHyperparameterTuningJob' => null,
    'trials' => [
        [
                'allMetrics' => [
                                [
                                                                'objectiveValue' => '',
                                                                'trainingStep' => ''
                                ]
                ],
                'builtInAlgorithmOutput' => [
                                
                ],
                'endTime' => '',
                'finalMetric' => [
                                
                ],
                'hyperparameters' => [
                                
                ],
                'isTrialStoppedEarly' => null,
                'startTime' => '',
                'state' => '',
                'trialId' => '',
                'webAccessUris' => [
                                
                ]
        ]
    ],
    'webAccessUris' => [
        
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'createTime' => '',
  'endTime' => '',
  'errorMessage' => '',
  'etag' => '',
  'jobId' => '',
  'jobPosition' => '',
  'labels' => [
    
  ],
  'predictionInput' => [
    'batchSize' => '',
    'dataFormat' => '',
    'inputPaths' => [
        
    ],
    'maxWorkerCount' => '',
    'modelName' => '',
    'outputDataFormat' => '',
    'outputPath' => '',
    'region' => '',
    'runtimeVersion' => '',
    'signatureName' => '',
    'uri' => '',
    'versionName' => ''
  ],
  'predictionOutput' => [
    'errorCount' => '',
    'nodeHours' => '',
    'outputPath' => '',
    'predictionCount' => ''
  ],
  'startTime' => '',
  'state' => '',
  'trainingInput' => [
    'args' => [
        
    ],
    'enableWebAccess' => null,
    'encryptionConfig' => [
        'kmsKeyName' => ''
    ],
    'evaluatorConfig' => [
        'acceleratorConfig' => [
                'count' => '',
                'type' => ''
        ],
        'containerArgs' => [
                
        ],
        'containerCommand' => [
                
        ],
        'diskConfig' => [
                'bootDiskSizeGb' => 0,
                'bootDiskType' => ''
        ],
        'imageUri' => '',
        'tpuTfVersion' => ''
    ],
    'evaluatorCount' => '',
    'evaluatorType' => '',
    'hyperparameters' => [
        'algorithm' => '',
        'enableTrialEarlyStopping' => null,
        'goal' => '',
        'hyperparameterMetricTag' => '',
        'maxFailedTrials' => 0,
        'maxParallelTrials' => 0,
        'maxTrials' => 0,
        'params' => [
                [
                                'categoricalValues' => [
                                                                
                                ],
                                'discreteValues' => [
                                                                
                                ],
                                'maxValue' => '',
                                'minValue' => '',
                                'parameterName' => '',
                                'scaleType' => '',
                                'type' => ''
                ]
        ],
        'resumePreviousJobId' => ''
    ],
    'jobDir' => '',
    'masterConfig' => [
        
    ],
    'masterType' => '',
    'network' => '',
    'packageUris' => [
        
    ],
    'parameterServerConfig' => [
        
    ],
    'parameterServerCount' => '',
    'parameterServerType' => '',
    'pythonModule' => '',
    'pythonVersion' => '',
    'region' => '',
    'runtimeVersion' => '',
    'scaleTier' => '',
    'scheduling' => [
        'maxRunningTime' => '',
        'maxWaitTime' => '',
        'priority' => 0
    ],
    'serviceAccount' => '',
    'useChiefInTfConfig' => null,
    'workerConfig' => [
        
    ],
    'workerCount' => '',
    'workerType' => ''
  ],
  'trainingOutput' => [
    'builtInAlgorithmOutput' => [
        'framework' => '',
        'modelPath' => '',
        'pythonVersion' => '',
        'runtimeVersion' => ''
    ],
    'completedTrialCount' => '',
    'consumedMLUnits' => '',
    'hyperparameterMetricTag' => '',
    'isBuiltInAlgorithmJob' => null,
    'isHyperparameterTuningJob' => null,
    'trials' => [
        [
                'allMetrics' => [
                                [
                                                                'objectiveValue' => '',
                                                                'trainingStep' => ''
                                ]
                ],
                'builtInAlgorithmOutput' => [
                                
                ],
                'endTime' => '',
                'finalMetric' => [
                                
                ],
                'hyperparameters' => [
                                
                ],
                'isTrialStoppedEarly' => null,
                'startTime' => '',
                'state' => '',
                'trialId' => '',
                'webAccessUris' => [
                                
                ]
        ]
    ],
    'webAccessUris' => [
        
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v1/: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}}/v1/:parent/jobs' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "createTime": "",
  "endTime": "",
  "errorMessage": "",
  "etag": "",
  "jobId": "",
  "jobPosition": "",
  "labels": {},
  "predictionInput": {
    "batchSize": "",
    "dataFormat": "",
    "inputPaths": [],
    "maxWorkerCount": "",
    "modelName": "",
    "outputDataFormat": "",
    "outputPath": "",
    "region": "",
    "runtimeVersion": "",
    "signatureName": "",
    "uri": "",
    "versionName": ""
  },
  "predictionOutput": {
    "errorCount": "",
    "nodeHours": "",
    "outputPath": "",
    "predictionCount": ""
  },
  "startTime": "",
  "state": "",
  "trainingInput": {
    "args": [],
    "enableWebAccess": false,
    "encryptionConfig": {
      "kmsKeyName": ""
    },
    "evaluatorConfig": {
      "acceleratorConfig": {
        "count": "",
        "type": ""
      },
      "containerArgs": [],
      "containerCommand": [],
      "diskConfig": {
        "bootDiskSizeGb": 0,
        "bootDiskType": ""
      },
      "imageUri": "",
      "tpuTfVersion": ""
    },
    "evaluatorCount": "",
    "evaluatorType": "",
    "hyperparameters": {
      "algorithm": "",
      "enableTrialEarlyStopping": false,
      "goal": "",
      "hyperparameterMetricTag": "",
      "maxFailedTrials": 0,
      "maxParallelTrials": 0,
      "maxTrials": 0,
      "params": [
        {
          "categoricalValues": [],
          "discreteValues": [],
          "maxValue": "",
          "minValue": "",
          "parameterName": "",
          "scaleType": "",
          "type": ""
        }
      ],
      "resumePreviousJobId": ""
    },
    "jobDir": "",
    "masterConfig": {},
    "masterType": "",
    "network": "",
    "packageUris": [],
    "parameterServerConfig": {},
    "parameterServerCount": "",
    "parameterServerType": "",
    "pythonModule": "",
    "pythonVersion": "",
    "region": "",
    "runtimeVersion": "",
    "scaleTier": "",
    "scheduling": {
      "maxRunningTime": "",
      "maxWaitTime": "",
      "priority": 0
    },
    "serviceAccount": "",
    "useChiefInTfConfig": false,
    "workerConfig": {},
    "workerCount": "",
    "workerType": ""
  },
  "trainingOutput": {
    "builtInAlgorithmOutput": {
      "framework": "",
      "modelPath": "",
      "pythonVersion": "",
      "runtimeVersion": ""
    },
    "completedTrialCount": "",
    "consumedMLUnits": "",
    "hyperparameterMetricTag": "",
    "isBuiltInAlgorithmJob": false,
    "isHyperparameterTuningJob": false,
    "trials": [
      {
        "allMetrics": [
          {
            "objectiveValue": "",
            "trainingStep": ""
          }
        ],
        "builtInAlgorithmOutput": {},
        "endTime": "",
        "finalMetric": {},
        "hyperparameters": {},
        "isTrialStoppedEarly": false,
        "startTime": "",
        "state": "",
        "trialId": "",
        "webAccessUris": {}
      }
    ],
    "webAccessUris": {}
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:parent/jobs' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "createTime": "",
  "endTime": "",
  "errorMessage": "",
  "etag": "",
  "jobId": "",
  "jobPosition": "",
  "labels": {},
  "predictionInput": {
    "batchSize": "",
    "dataFormat": "",
    "inputPaths": [],
    "maxWorkerCount": "",
    "modelName": "",
    "outputDataFormat": "",
    "outputPath": "",
    "region": "",
    "runtimeVersion": "",
    "signatureName": "",
    "uri": "",
    "versionName": ""
  },
  "predictionOutput": {
    "errorCount": "",
    "nodeHours": "",
    "outputPath": "",
    "predictionCount": ""
  },
  "startTime": "",
  "state": "",
  "trainingInput": {
    "args": [],
    "enableWebAccess": false,
    "encryptionConfig": {
      "kmsKeyName": ""
    },
    "evaluatorConfig": {
      "acceleratorConfig": {
        "count": "",
        "type": ""
      },
      "containerArgs": [],
      "containerCommand": [],
      "diskConfig": {
        "bootDiskSizeGb": 0,
        "bootDiskType": ""
      },
      "imageUri": "",
      "tpuTfVersion": ""
    },
    "evaluatorCount": "",
    "evaluatorType": "",
    "hyperparameters": {
      "algorithm": "",
      "enableTrialEarlyStopping": false,
      "goal": "",
      "hyperparameterMetricTag": "",
      "maxFailedTrials": 0,
      "maxParallelTrials": 0,
      "maxTrials": 0,
      "params": [
        {
          "categoricalValues": [],
          "discreteValues": [],
          "maxValue": "",
          "minValue": "",
          "parameterName": "",
          "scaleType": "",
          "type": ""
        }
      ],
      "resumePreviousJobId": ""
    },
    "jobDir": "",
    "masterConfig": {},
    "masterType": "",
    "network": "",
    "packageUris": [],
    "parameterServerConfig": {},
    "parameterServerCount": "",
    "parameterServerType": "",
    "pythonModule": "",
    "pythonVersion": "",
    "region": "",
    "runtimeVersion": "",
    "scaleTier": "",
    "scheduling": {
      "maxRunningTime": "",
      "maxWaitTime": "",
      "priority": 0
    },
    "serviceAccount": "",
    "useChiefInTfConfig": false,
    "workerConfig": {},
    "workerCount": "",
    "workerType": ""
  },
  "trainingOutput": {
    "builtInAlgorithmOutput": {
      "framework": "",
      "modelPath": "",
      "pythonVersion": "",
      "runtimeVersion": ""
    },
    "completedTrialCount": "",
    "consumedMLUnits": "",
    "hyperparameterMetricTag": "",
    "isBuiltInAlgorithmJob": false,
    "isHyperparameterTuningJob": false,
    "trials": [
      {
        "allMetrics": [
          {
            "objectiveValue": "",
            "trainingStep": ""
          }
        ],
        "builtInAlgorithmOutput": {},
        "endTime": "",
        "finalMetric": {},
        "hyperparameters": {},
        "isTrialStoppedEarly": false,
        "startTime": "",
        "state": "",
        "trialId": "",
        "webAccessUris": {}
      }
    ],
    "webAccessUris": {}
  }
}'
import http.client

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

payload = "{\n  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}"

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

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

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

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

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

payload = {
    "createTime": "",
    "endTime": "",
    "errorMessage": "",
    "etag": "",
    "jobId": "",
    "jobPosition": "",
    "labels": {},
    "predictionInput": {
        "batchSize": "",
        "dataFormat": "",
        "inputPaths": [],
        "maxWorkerCount": "",
        "modelName": "",
        "outputDataFormat": "",
        "outputPath": "",
        "region": "",
        "runtimeVersion": "",
        "signatureName": "",
        "uri": "",
        "versionName": ""
    },
    "predictionOutput": {
        "errorCount": "",
        "nodeHours": "",
        "outputPath": "",
        "predictionCount": ""
    },
    "startTime": "",
    "state": "",
    "trainingInput": {
        "args": [],
        "enableWebAccess": False,
        "encryptionConfig": { "kmsKeyName": "" },
        "evaluatorConfig": {
            "acceleratorConfig": {
                "count": "",
                "type": ""
            },
            "containerArgs": [],
            "containerCommand": [],
            "diskConfig": {
                "bootDiskSizeGb": 0,
                "bootDiskType": ""
            },
            "imageUri": "",
            "tpuTfVersion": ""
        },
        "evaluatorCount": "",
        "evaluatorType": "",
        "hyperparameters": {
            "algorithm": "",
            "enableTrialEarlyStopping": False,
            "goal": "",
            "hyperparameterMetricTag": "",
            "maxFailedTrials": 0,
            "maxParallelTrials": 0,
            "maxTrials": 0,
            "params": [
                {
                    "categoricalValues": [],
                    "discreteValues": [],
                    "maxValue": "",
                    "minValue": "",
                    "parameterName": "",
                    "scaleType": "",
                    "type": ""
                }
            ],
            "resumePreviousJobId": ""
        },
        "jobDir": "",
        "masterConfig": {},
        "masterType": "",
        "network": "",
        "packageUris": [],
        "parameterServerConfig": {},
        "parameterServerCount": "",
        "parameterServerType": "",
        "pythonModule": "",
        "pythonVersion": "",
        "region": "",
        "runtimeVersion": "",
        "scaleTier": "",
        "scheduling": {
            "maxRunningTime": "",
            "maxWaitTime": "",
            "priority": 0
        },
        "serviceAccount": "",
        "useChiefInTfConfig": False,
        "workerConfig": {},
        "workerCount": "",
        "workerType": ""
    },
    "trainingOutput": {
        "builtInAlgorithmOutput": {
            "framework": "",
            "modelPath": "",
            "pythonVersion": "",
            "runtimeVersion": ""
        },
        "completedTrialCount": "",
        "consumedMLUnits": "",
        "hyperparameterMetricTag": "",
        "isBuiltInAlgorithmJob": False,
        "isHyperparameterTuningJob": False,
        "trials": [
            {
                "allMetrics": [
                    {
                        "objectiveValue": "",
                        "trainingStep": ""
                    }
                ],
                "builtInAlgorithmOutput": {},
                "endTime": "",
                "finalMetric": {},
                "hyperparameters": {},
                "isTrialStoppedEarly": False,
                "startTime": "",
                "state": "",
                "trialId": "",
                "webAccessUris": {}
            }
        ],
        "webAccessUris": {}
    }
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v1/: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  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}"

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

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

response = conn.post('/baseUrl/v1/:parent/jobs') do |req|
  req.body = "{\n  \"createTime\": \"\",\n  \"endTime\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"jobId\": \"\",\n  \"jobPosition\": \"\",\n  \"labels\": {},\n  \"predictionInput\": {\n    \"batchSize\": \"\",\n    \"dataFormat\": \"\",\n    \"inputPaths\": [],\n    \"maxWorkerCount\": \"\",\n    \"modelName\": \"\",\n    \"outputDataFormat\": \"\",\n    \"outputPath\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"signatureName\": \"\",\n    \"uri\": \"\",\n    \"versionName\": \"\"\n  },\n  \"predictionOutput\": {\n    \"errorCount\": \"\",\n    \"nodeHours\": \"\",\n    \"outputPath\": \"\",\n    \"predictionCount\": \"\"\n  },\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trainingInput\": {\n    \"args\": [],\n    \"enableWebAccess\": false,\n    \"encryptionConfig\": {\n      \"kmsKeyName\": \"\"\n    },\n    \"evaluatorConfig\": {\n      \"acceleratorConfig\": {\n        \"count\": \"\",\n        \"type\": \"\"\n      },\n      \"containerArgs\": [],\n      \"containerCommand\": [],\n      \"diskConfig\": {\n        \"bootDiskSizeGb\": 0,\n        \"bootDiskType\": \"\"\n      },\n      \"imageUri\": \"\",\n      \"tpuTfVersion\": \"\"\n    },\n    \"evaluatorCount\": \"\",\n    \"evaluatorType\": \"\",\n    \"hyperparameters\": {\n      \"algorithm\": \"\",\n      \"enableTrialEarlyStopping\": false,\n      \"goal\": \"\",\n      \"hyperparameterMetricTag\": \"\",\n      \"maxFailedTrials\": 0,\n      \"maxParallelTrials\": 0,\n      \"maxTrials\": 0,\n      \"params\": [\n        {\n          \"categoricalValues\": [],\n          \"discreteValues\": [],\n          \"maxValue\": \"\",\n          \"minValue\": \"\",\n          \"parameterName\": \"\",\n          \"scaleType\": \"\",\n          \"type\": \"\"\n        }\n      ],\n      \"resumePreviousJobId\": \"\"\n    },\n    \"jobDir\": \"\",\n    \"masterConfig\": {},\n    \"masterType\": \"\",\n    \"network\": \"\",\n    \"packageUris\": [],\n    \"parameterServerConfig\": {},\n    \"parameterServerCount\": \"\",\n    \"parameterServerType\": \"\",\n    \"pythonModule\": \"\",\n    \"pythonVersion\": \"\",\n    \"region\": \"\",\n    \"runtimeVersion\": \"\",\n    \"scaleTier\": \"\",\n    \"scheduling\": {\n      \"maxRunningTime\": \"\",\n      \"maxWaitTime\": \"\",\n      \"priority\": 0\n    },\n    \"serviceAccount\": \"\",\n    \"useChiefInTfConfig\": false,\n    \"workerConfig\": {},\n    \"workerCount\": \"\",\n    \"workerType\": \"\"\n  },\n  \"trainingOutput\": {\n    \"builtInAlgorithmOutput\": {\n      \"framework\": \"\",\n      \"modelPath\": \"\",\n      \"pythonVersion\": \"\",\n      \"runtimeVersion\": \"\"\n    },\n    \"completedTrialCount\": \"\",\n    \"consumedMLUnits\": \"\",\n    \"hyperparameterMetricTag\": \"\",\n    \"isBuiltInAlgorithmJob\": false,\n    \"isHyperparameterTuningJob\": false,\n    \"trials\": [\n      {\n        \"allMetrics\": [\n          {\n            \"objectiveValue\": \"\",\n            \"trainingStep\": \"\"\n          }\n        ],\n        \"builtInAlgorithmOutput\": {},\n        \"endTime\": \"\",\n        \"finalMetric\": {},\n        \"hyperparameters\": {},\n        \"isTrialStoppedEarly\": false,\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trialId\": \"\",\n        \"webAccessUris\": {}\n      }\n    ],\n    \"webAccessUris\": {}\n  }\n}"
end

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

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

    let payload = json!({
        "createTime": "",
        "endTime": "",
        "errorMessage": "",
        "etag": "",
        "jobId": "",
        "jobPosition": "",
        "labels": json!({}),
        "predictionInput": json!({
            "batchSize": "",
            "dataFormat": "",
            "inputPaths": (),
            "maxWorkerCount": "",
            "modelName": "",
            "outputDataFormat": "",
            "outputPath": "",
            "region": "",
            "runtimeVersion": "",
            "signatureName": "",
            "uri": "",
            "versionName": ""
        }),
        "predictionOutput": json!({
            "errorCount": "",
            "nodeHours": "",
            "outputPath": "",
            "predictionCount": ""
        }),
        "startTime": "",
        "state": "",
        "trainingInput": json!({
            "args": (),
            "enableWebAccess": false,
            "encryptionConfig": json!({"kmsKeyName": ""}),
            "evaluatorConfig": json!({
                "acceleratorConfig": json!({
                    "count": "",
                    "type": ""
                }),
                "containerArgs": (),
                "containerCommand": (),
                "diskConfig": json!({
                    "bootDiskSizeGb": 0,
                    "bootDiskType": ""
                }),
                "imageUri": "",
                "tpuTfVersion": ""
            }),
            "evaluatorCount": "",
            "evaluatorType": "",
            "hyperparameters": json!({
                "algorithm": "",
                "enableTrialEarlyStopping": false,
                "goal": "",
                "hyperparameterMetricTag": "",
                "maxFailedTrials": 0,
                "maxParallelTrials": 0,
                "maxTrials": 0,
                "params": (
                    json!({
                        "categoricalValues": (),
                        "discreteValues": (),
                        "maxValue": "",
                        "minValue": "",
                        "parameterName": "",
                        "scaleType": "",
                        "type": ""
                    })
                ),
                "resumePreviousJobId": ""
            }),
            "jobDir": "",
            "masterConfig": json!({}),
            "masterType": "",
            "network": "",
            "packageUris": (),
            "parameterServerConfig": json!({}),
            "parameterServerCount": "",
            "parameterServerType": "",
            "pythonModule": "",
            "pythonVersion": "",
            "region": "",
            "runtimeVersion": "",
            "scaleTier": "",
            "scheduling": json!({
                "maxRunningTime": "",
                "maxWaitTime": "",
                "priority": 0
            }),
            "serviceAccount": "",
            "useChiefInTfConfig": false,
            "workerConfig": json!({}),
            "workerCount": "",
            "workerType": ""
        }),
        "trainingOutput": json!({
            "builtInAlgorithmOutput": json!({
                "framework": "",
                "modelPath": "",
                "pythonVersion": "",
                "runtimeVersion": ""
            }),
            "completedTrialCount": "",
            "consumedMLUnits": "",
            "hyperparameterMetricTag": "",
            "isBuiltInAlgorithmJob": false,
            "isHyperparameterTuningJob": false,
            "trials": (
                json!({
                    "allMetrics": (
                        json!({
                            "objectiveValue": "",
                            "trainingStep": ""
                        })
                    ),
                    "builtInAlgorithmOutput": json!({}),
                    "endTime": "",
                    "finalMetric": json!({}),
                    "hyperparameters": json!({}),
                    "isTrialStoppedEarly": false,
                    "startTime": "",
                    "state": "",
                    "trialId": "",
                    "webAccessUris": json!({})
                })
            ),
            "webAccessUris": json!({})
        })
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:parent/jobs \
  --header 'content-type: application/json' \
  --data '{
  "createTime": "",
  "endTime": "",
  "errorMessage": "",
  "etag": "",
  "jobId": "",
  "jobPosition": "",
  "labels": {},
  "predictionInput": {
    "batchSize": "",
    "dataFormat": "",
    "inputPaths": [],
    "maxWorkerCount": "",
    "modelName": "",
    "outputDataFormat": "",
    "outputPath": "",
    "region": "",
    "runtimeVersion": "",
    "signatureName": "",
    "uri": "",
    "versionName": ""
  },
  "predictionOutput": {
    "errorCount": "",
    "nodeHours": "",
    "outputPath": "",
    "predictionCount": ""
  },
  "startTime": "",
  "state": "",
  "trainingInput": {
    "args": [],
    "enableWebAccess": false,
    "encryptionConfig": {
      "kmsKeyName": ""
    },
    "evaluatorConfig": {
      "acceleratorConfig": {
        "count": "",
        "type": ""
      },
      "containerArgs": [],
      "containerCommand": [],
      "diskConfig": {
        "bootDiskSizeGb": 0,
        "bootDiskType": ""
      },
      "imageUri": "",
      "tpuTfVersion": ""
    },
    "evaluatorCount": "",
    "evaluatorType": "",
    "hyperparameters": {
      "algorithm": "",
      "enableTrialEarlyStopping": false,
      "goal": "",
      "hyperparameterMetricTag": "",
      "maxFailedTrials": 0,
      "maxParallelTrials": 0,
      "maxTrials": 0,
      "params": [
        {
          "categoricalValues": [],
          "discreteValues": [],
          "maxValue": "",
          "minValue": "",
          "parameterName": "",
          "scaleType": "",
          "type": ""
        }
      ],
      "resumePreviousJobId": ""
    },
    "jobDir": "",
    "masterConfig": {},
    "masterType": "",
    "network": "",
    "packageUris": [],
    "parameterServerConfig": {},
    "parameterServerCount": "",
    "parameterServerType": "",
    "pythonModule": "",
    "pythonVersion": "",
    "region": "",
    "runtimeVersion": "",
    "scaleTier": "",
    "scheduling": {
      "maxRunningTime": "",
      "maxWaitTime": "",
      "priority": 0
    },
    "serviceAccount": "",
    "useChiefInTfConfig": false,
    "workerConfig": {},
    "workerCount": "",
    "workerType": ""
  },
  "trainingOutput": {
    "builtInAlgorithmOutput": {
      "framework": "",
      "modelPath": "",
      "pythonVersion": "",
      "runtimeVersion": ""
    },
    "completedTrialCount": "",
    "consumedMLUnits": "",
    "hyperparameterMetricTag": "",
    "isBuiltInAlgorithmJob": false,
    "isHyperparameterTuningJob": false,
    "trials": [
      {
        "allMetrics": [
          {
            "objectiveValue": "",
            "trainingStep": ""
          }
        ],
        "builtInAlgorithmOutput": {},
        "endTime": "",
        "finalMetric": {},
        "hyperparameters": {},
        "isTrialStoppedEarly": false,
        "startTime": "",
        "state": "",
        "trialId": "",
        "webAccessUris": {}
      }
    ],
    "webAccessUris": {}
  }
}'
echo '{
  "createTime": "",
  "endTime": "",
  "errorMessage": "",
  "etag": "",
  "jobId": "",
  "jobPosition": "",
  "labels": {},
  "predictionInput": {
    "batchSize": "",
    "dataFormat": "",
    "inputPaths": [],
    "maxWorkerCount": "",
    "modelName": "",
    "outputDataFormat": "",
    "outputPath": "",
    "region": "",
    "runtimeVersion": "",
    "signatureName": "",
    "uri": "",
    "versionName": ""
  },
  "predictionOutput": {
    "errorCount": "",
    "nodeHours": "",
    "outputPath": "",
    "predictionCount": ""
  },
  "startTime": "",
  "state": "",
  "trainingInput": {
    "args": [],
    "enableWebAccess": false,
    "encryptionConfig": {
      "kmsKeyName": ""
    },
    "evaluatorConfig": {
      "acceleratorConfig": {
        "count": "",
        "type": ""
      },
      "containerArgs": [],
      "containerCommand": [],
      "diskConfig": {
        "bootDiskSizeGb": 0,
        "bootDiskType": ""
      },
      "imageUri": "",
      "tpuTfVersion": ""
    },
    "evaluatorCount": "",
    "evaluatorType": "",
    "hyperparameters": {
      "algorithm": "",
      "enableTrialEarlyStopping": false,
      "goal": "",
      "hyperparameterMetricTag": "",
      "maxFailedTrials": 0,
      "maxParallelTrials": 0,
      "maxTrials": 0,
      "params": [
        {
          "categoricalValues": [],
          "discreteValues": [],
          "maxValue": "",
          "minValue": "",
          "parameterName": "",
          "scaleType": "",
          "type": ""
        }
      ],
      "resumePreviousJobId": ""
    },
    "jobDir": "",
    "masterConfig": {},
    "masterType": "",
    "network": "",
    "packageUris": [],
    "parameterServerConfig": {},
    "parameterServerCount": "",
    "parameterServerType": "",
    "pythonModule": "",
    "pythonVersion": "",
    "region": "",
    "runtimeVersion": "",
    "scaleTier": "",
    "scheduling": {
      "maxRunningTime": "",
      "maxWaitTime": "",
      "priority": 0
    },
    "serviceAccount": "",
    "useChiefInTfConfig": false,
    "workerConfig": {},
    "workerCount": "",
    "workerType": ""
  },
  "trainingOutput": {
    "builtInAlgorithmOutput": {
      "framework": "",
      "modelPath": "",
      "pythonVersion": "",
      "runtimeVersion": ""
    },
    "completedTrialCount": "",
    "consumedMLUnits": "",
    "hyperparameterMetricTag": "",
    "isBuiltInAlgorithmJob": false,
    "isHyperparameterTuningJob": false,
    "trials": [
      {
        "allMetrics": [
          {
            "objectiveValue": "",
            "trainingStep": ""
          }
        ],
        "builtInAlgorithmOutput": {},
        "endTime": "",
        "finalMetric": {},
        "hyperparameters": {},
        "isTrialStoppedEarly": false,
        "startTime": "",
        "state": "",
        "trialId": "",
        "webAccessUris": {}
      }
    ],
    "webAccessUris": {}
  }
}' |  \
  http POST {{baseUrl}}/v1/:parent/jobs \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "createTime": "",\n  "endTime": "",\n  "errorMessage": "",\n  "etag": "",\n  "jobId": "",\n  "jobPosition": "",\n  "labels": {},\n  "predictionInput": {\n    "batchSize": "",\n    "dataFormat": "",\n    "inputPaths": [],\n    "maxWorkerCount": "",\n    "modelName": "",\n    "outputDataFormat": "",\n    "outputPath": "",\n    "region": "",\n    "runtimeVersion": "",\n    "signatureName": "",\n    "uri": "",\n    "versionName": ""\n  },\n  "predictionOutput": {\n    "errorCount": "",\n    "nodeHours": "",\n    "outputPath": "",\n    "predictionCount": ""\n  },\n  "startTime": "",\n  "state": "",\n  "trainingInput": {\n    "args": [],\n    "enableWebAccess": false,\n    "encryptionConfig": {\n      "kmsKeyName": ""\n    },\n    "evaluatorConfig": {\n      "acceleratorConfig": {\n        "count": "",\n        "type": ""\n      },\n      "containerArgs": [],\n      "containerCommand": [],\n      "diskConfig": {\n        "bootDiskSizeGb": 0,\n        "bootDiskType": ""\n      },\n      "imageUri": "",\n      "tpuTfVersion": ""\n    },\n    "evaluatorCount": "",\n    "evaluatorType": "",\n    "hyperparameters": {\n      "algorithm": "",\n      "enableTrialEarlyStopping": false,\n      "goal": "",\n      "hyperparameterMetricTag": "",\n      "maxFailedTrials": 0,\n      "maxParallelTrials": 0,\n      "maxTrials": 0,\n      "params": [\n        {\n          "categoricalValues": [],\n          "discreteValues": [],\n          "maxValue": "",\n          "minValue": "",\n          "parameterName": "",\n          "scaleType": "",\n          "type": ""\n        }\n      ],\n      "resumePreviousJobId": ""\n    },\n    "jobDir": "",\n    "masterConfig": {},\n    "masterType": "",\n    "network": "",\n    "packageUris": [],\n    "parameterServerConfig": {},\n    "parameterServerCount": "",\n    "parameterServerType": "",\n    "pythonModule": "",\n    "pythonVersion": "",\n    "region": "",\n    "runtimeVersion": "",\n    "scaleTier": "",\n    "scheduling": {\n      "maxRunningTime": "",\n      "maxWaitTime": "",\n      "priority": 0\n    },\n    "serviceAccount": "",\n    "useChiefInTfConfig": false,\n    "workerConfig": {},\n    "workerCount": "",\n    "workerType": ""\n  },\n  "trainingOutput": {\n    "builtInAlgorithmOutput": {\n      "framework": "",\n      "modelPath": "",\n      "pythonVersion": "",\n      "runtimeVersion": ""\n    },\n    "completedTrialCount": "",\n    "consumedMLUnits": "",\n    "hyperparameterMetricTag": "",\n    "isBuiltInAlgorithmJob": false,\n    "isHyperparameterTuningJob": false,\n    "trials": [\n      {\n        "allMetrics": [\n          {\n            "objectiveValue": "",\n            "trainingStep": ""\n          }\n        ],\n        "builtInAlgorithmOutput": {},\n        "endTime": "",\n        "finalMetric": {},\n        "hyperparameters": {},\n        "isTrialStoppedEarly": false,\n        "startTime": "",\n        "state": "",\n        "trialId": "",\n        "webAccessUris": {}\n      }\n    ],\n    "webAccessUris": {}\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v1/:parent/jobs
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "createTime": "",
  "endTime": "",
  "errorMessage": "",
  "etag": "",
  "jobId": "",
  "jobPosition": "",
  "labels": [],
  "predictionInput": [
    "batchSize": "",
    "dataFormat": "",
    "inputPaths": [],
    "maxWorkerCount": "",
    "modelName": "",
    "outputDataFormat": "",
    "outputPath": "",
    "region": "",
    "runtimeVersion": "",
    "signatureName": "",
    "uri": "",
    "versionName": ""
  ],
  "predictionOutput": [
    "errorCount": "",
    "nodeHours": "",
    "outputPath": "",
    "predictionCount": ""
  ],
  "startTime": "",
  "state": "",
  "trainingInput": [
    "args": [],
    "enableWebAccess": false,
    "encryptionConfig": ["kmsKeyName": ""],
    "evaluatorConfig": [
      "acceleratorConfig": [
        "count": "",
        "type": ""
      ],
      "containerArgs": [],
      "containerCommand": [],
      "diskConfig": [
        "bootDiskSizeGb": 0,
        "bootDiskType": ""
      ],
      "imageUri": "",
      "tpuTfVersion": ""
    ],
    "evaluatorCount": "",
    "evaluatorType": "",
    "hyperparameters": [
      "algorithm": "",
      "enableTrialEarlyStopping": false,
      "goal": "",
      "hyperparameterMetricTag": "",
      "maxFailedTrials": 0,
      "maxParallelTrials": 0,
      "maxTrials": 0,
      "params": [
        [
          "categoricalValues": [],
          "discreteValues": [],
          "maxValue": "",
          "minValue": "",
          "parameterName": "",
          "scaleType": "",
          "type": ""
        ]
      ],
      "resumePreviousJobId": ""
    ],
    "jobDir": "",
    "masterConfig": [],
    "masterType": "",
    "network": "",
    "packageUris": [],
    "parameterServerConfig": [],
    "parameterServerCount": "",
    "parameterServerType": "",
    "pythonModule": "",
    "pythonVersion": "",
    "region": "",
    "runtimeVersion": "",
    "scaleTier": "",
    "scheduling": [
      "maxRunningTime": "",
      "maxWaitTime": "",
      "priority": 0
    ],
    "serviceAccount": "",
    "useChiefInTfConfig": false,
    "workerConfig": [],
    "workerCount": "",
    "workerType": ""
  ],
  "trainingOutput": [
    "builtInAlgorithmOutput": [
      "framework": "",
      "modelPath": "",
      "pythonVersion": "",
      "runtimeVersion": ""
    ],
    "completedTrialCount": "",
    "consumedMLUnits": "",
    "hyperparameterMetricTag": "",
    "isBuiltInAlgorithmJob": false,
    "isHyperparameterTuningJob": false,
    "trials": [
      [
        "allMetrics": [
          [
            "objectiveValue": "",
            "trainingStep": ""
          ]
        ],
        "builtInAlgorithmOutput": [],
        "endTime": "",
        "finalMetric": [],
        "hyperparameters": [],
        "isTrialStoppedEarly": false,
        "startTime": "",
        "state": "",
        "trialId": "",
        "webAccessUris": []
      ]
    ],
    "webAccessUris": []
  ]
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/: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()
GET ml.projects.jobs.list
{{baseUrl}}/v1/: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}}/v1/:parent/jobs");

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

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

url = "{{baseUrl}}/v1/: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}}/v1/: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}}/v1/:parent/jobs");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

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

func main() {

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

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

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

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

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

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

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v1/: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/v1/: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}}/v1/: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}}/v1/: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}}/v1/: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}}/v1/: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}}/v1/: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}}/v1/:parent/jobs" in

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

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

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

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

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

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

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

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

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

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

response = requests.get(url)

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/v1/:parent/locations")
require "http/client"

url = "{{baseUrl}}/v1/:parent/locations"

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

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

func main() {

	url := "{{baseUrl}}/v1/:parent/locations"

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

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

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

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

}
GET /baseUrl/v1/:parent/locations HTTP/1.1
Host: example.com

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

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

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

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

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

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

xhr.open('GET', '{{baseUrl}}/v1/:parent/locations');

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

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/locations'};

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

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

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

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

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

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/locations'};

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/locations'};

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

const url = '{{baseUrl}}/v1/:parent/locations';
const options = {method: 'GET'};

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:parent/locations" in

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

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

curl_close($curl);

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

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

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

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

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

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

conn.request("GET", "/baseUrl/v1/:parent/locations")

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

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

url = "{{baseUrl}}/v1/:parent/locations"

response = requests.get(url)

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

url <- "{{baseUrl}}/v1/:parent/locations"

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

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

url = URI("{{baseUrl}}/v1/:parent/locations")

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

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

parent
BODY json

{
  "createTime": "",
  "inactiveReason": "",
  "name": "",
  "state": "",
  "studyConfig": {
    "algorithm": "",
    "automatedStoppingConfig": {
      "decayCurveStoppingConfig": {
        "useElapsedTime": false
      },
      "medianAutomatedStoppingConfig": {
        "useElapsedTime": false
      }
    },
    "metrics": [
      {
        "goal": "",
        "metric": ""
      }
    ],
    "parameters": [
      {
        "categoricalValueSpec": {
          "values": []
        },
        "childParameterSpecs": [],
        "discreteValueSpec": {
          "values": []
        },
        "doubleValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "integerValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "parameter": "",
        "parentCategoricalValues": {
          "values": []
        },
        "parentDiscreteValues": {
          "values": []
        },
        "parentIntValues": {
          "values": []
        },
        "scaleType": "",
        "type": ""
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

struct curl_slist *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  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}");

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

(client/post "{{baseUrl}}/v1/:parent/studies" {:content-type :json
                                                               :form-params {:createTime ""
                                                                             :inactiveReason ""
                                                                             :name ""
                                                                             :state ""
                                                                             :studyConfig {:algorithm ""
                                                                                           :automatedStoppingConfig {:decayCurveStoppingConfig {:useElapsedTime false}
                                                                                                                     :medianAutomatedStoppingConfig {:useElapsedTime false}}
                                                                                           :metrics [{:goal ""
                                                                                                      :metric ""}]
                                                                                           :parameters [{:categoricalValueSpec {:values []}
                                                                                                         :childParameterSpecs []
                                                                                                         :discreteValueSpec {:values []}
                                                                                                         :doubleValueSpec {:maxValue ""
                                                                                                                           :minValue ""}
                                                                                                         :integerValueSpec {:maxValue ""
                                                                                                                            :minValue ""}
                                                                                                         :parameter ""
                                                                                                         :parentCategoricalValues {:values []}
                                                                                                         :parentDiscreteValues {:values []}
                                                                                                         :parentIntValues {:values []}
                                                                                                         :scaleType ""
                                                                                                         :type ""}]}}})
require "http/client"

url = "{{baseUrl}}/v1/:parent/studies"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:parent/studies"),
    Content = new StringContent("{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:parent/studies");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1/:parent/studies"

	payload := strings.NewReader("{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v1/:parent/studies HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1063

{
  "createTime": "",
  "inactiveReason": "",
  "name": "",
  "state": "",
  "studyConfig": {
    "algorithm": "",
    "automatedStoppingConfig": {
      "decayCurveStoppingConfig": {
        "useElapsedTime": false
      },
      "medianAutomatedStoppingConfig": {
        "useElapsedTime": false
      }
    },
    "metrics": [
      {
        "goal": "",
        "metric": ""
      }
    ],
    "parameters": [
      {
        "categoricalValueSpec": {
          "values": []
        },
        "childParameterSpecs": [],
        "discreteValueSpec": {
          "values": []
        },
        "doubleValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "integerValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "parameter": "",
        "parentCategoricalValues": {
          "values": []
        },
        "parentDiscreteValues": {
          "values": []
        },
        "parentIntValues": {
          "values": []
        },
        "scaleType": "",
        "type": ""
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:parent/studies")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:parent/studies"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:parent/studies")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:parent/studies")
  .header("content-type", "application/json")
  .body("{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  createTime: '',
  inactiveReason: '',
  name: '',
  state: '',
  studyConfig: {
    algorithm: '',
    automatedStoppingConfig: {
      decayCurveStoppingConfig: {
        useElapsedTime: false
      },
      medianAutomatedStoppingConfig: {
        useElapsedTime: false
      }
    },
    metrics: [
      {
        goal: '',
        metric: ''
      }
    ],
    parameters: [
      {
        categoricalValueSpec: {
          values: []
        },
        childParameterSpecs: [],
        discreteValueSpec: {
          values: []
        },
        doubleValueSpec: {
          maxValue: '',
          minValue: ''
        },
        integerValueSpec: {
          maxValue: '',
          minValue: ''
        },
        parameter: '',
        parentCategoricalValues: {
          values: []
        },
        parentDiscreteValues: {
          values: []
        },
        parentIntValues: {
          values: []
        },
        scaleType: '',
        type: ''
      }
    ]
  }
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/studies',
  headers: {'content-type': 'application/json'},
  data: {
    createTime: '',
    inactiveReason: '',
    name: '',
    state: '',
    studyConfig: {
      algorithm: '',
      automatedStoppingConfig: {
        decayCurveStoppingConfig: {useElapsedTime: false},
        medianAutomatedStoppingConfig: {useElapsedTime: false}
      },
      metrics: [{goal: '', metric: ''}],
      parameters: [
        {
          categoricalValueSpec: {values: []},
          childParameterSpecs: [],
          discreteValueSpec: {values: []},
          doubleValueSpec: {maxValue: '', minValue: ''},
          integerValueSpec: {maxValue: '', minValue: ''},
          parameter: '',
          parentCategoricalValues: {values: []},
          parentDiscreteValues: {values: []},
          parentIntValues: {values: []},
          scaleType: '',
          type: ''
        }
      ]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:parent/studies';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"createTime":"","inactiveReason":"","name":"","state":"","studyConfig":{"algorithm":"","automatedStoppingConfig":{"decayCurveStoppingConfig":{"useElapsedTime":false},"medianAutomatedStoppingConfig":{"useElapsedTime":false}},"metrics":[{"goal":"","metric":""}],"parameters":[{"categoricalValueSpec":{"values":[]},"childParameterSpecs":[],"discreteValueSpec":{"values":[]},"doubleValueSpec":{"maxValue":"","minValue":""},"integerValueSpec":{"maxValue":"","minValue":""},"parameter":"","parentCategoricalValues":{"values":[]},"parentDiscreteValues":{"values":[]},"parentIntValues":{"values":[]},"scaleType":"","type":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:parent/studies',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "createTime": "",\n  "inactiveReason": "",\n  "name": "",\n  "state": "",\n  "studyConfig": {\n    "algorithm": "",\n    "automatedStoppingConfig": {\n      "decayCurveStoppingConfig": {\n        "useElapsedTime": false\n      },\n      "medianAutomatedStoppingConfig": {\n        "useElapsedTime": false\n      }\n    },\n    "metrics": [\n      {\n        "goal": "",\n        "metric": ""\n      }\n    ],\n    "parameters": [\n      {\n        "categoricalValueSpec": {\n          "values": []\n        },\n        "childParameterSpecs": [],\n        "discreteValueSpec": {\n          "values": []\n        },\n        "doubleValueSpec": {\n          "maxValue": "",\n          "minValue": ""\n        },\n        "integerValueSpec": {\n          "maxValue": "",\n          "minValue": ""\n        },\n        "parameter": "",\n        "parentCategoricalValues": {\n          "values": []\n        },\n        "parentDiscreteValues": {\n          "values": []\n        },\n        "parentIntValues": {\n          "values": []\n        },\n        "scaleType": "",\n        "type": ""\n      }\n    ]\n  }\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:parent/studies")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:parent/studies',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  createTime: '',
  inactiveReason: '',
  name: '',
  state: '',
  studyConfig: {
    algorithm: '',
    automatedStoppingConfig: {
      decayCurveStoppingConfig: {useElapsedTime: false},
      medianAutomatedStoppingConfig: {useElapsedTime: false}
    },
    metrics: [{goal: '', metric: ''}],
    parameters: [
      {
        categoricalValueSpec: {values: []},
        childParameterSpecs: [],
        discreteValueSpec: {values: []},
        doubleValueSpec: {maxValue: '', minValue: ''},
        integerValueSpec: {maxValue: '', minValue: ''},
        parameter: '',
        parentCategoricalValues: {values: []},
        parentDiscreteValues: {values: []},
        parentIntValues: {values: []},
        scaleType: '',
        type: ''
      }
    ]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/studies',
  headers: {'content-type': 'application/json'},
  body: {
    createTime: '',
    inactiveReason: '',
    name: '',
    state: '',
    studyConfig: {
      algorithm: '',
      automatedStoppingConfig: {
        decayCurveStoppingConfig: {useElapsedTime: false},
        medianAutomatedStoppingConfig: {useElapsedTime: false}
      },
      metrics: [{goal: '', metric: ''}],
      parameters: [
        {
          categoricalValueSpec: {values: []},
          childParameterSpecs: [],
          discreteValueSpec: {values: []},
          doubleValueSpec: {maxValue: '', minValue: ''},
          integerValueSpec: {maxValue: '', minValue: ''},
          parameter: '',
          parentCategoricalValues: {values: []},
          parentDiscreteValues: {values: []},
          parentIntValues: {values: []},
          scaleType: '',
          type: ''
        }
      ]
    }
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v1/:parent/studies');

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

req.type('json');
req.send({
  createTime: '',
  inactiveReason: '',
  name: '',
  state: '',
  studyConfig: {
    algorithm: '',
    automatedStoppingConfig: {
      decayCurveStoppingConfig: {
        useElapsedTime: false
      },
      medianAutomatedStoppingConfig: {
        useElapsedTime: false
      }
    },
    metrics: [
      {
        goal: '',
        metric: ''
      }
    ],
    parameters: [
      {
        categoricalValueSpec: {
          values: []
        },
        childParameterSpecs: [],
        discreteValueSpec: {
          values: []
        },
        doubleValueSpec: {
          maxValue: '',
          minValue: ''
        },
        integerValueSpec: {
          maxValue: '',
          minValue: ''
        },
        parameter: '',
        parentCategoricalValues: {
          values: []
        },
        parentDiscreteValues: {
          values: []
        },
        parentIntValues: {
          values: []
        },
        scaleType: '',
        type: ''
      }
    ]
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/studies',
  headers: {'content-type': 'application/json'},
  data: {
    createTime: '',
    inactiveReason: '',
    name: '',
    state: '',
    studyConfig: {
      algorithm: '',
      automatedStoppingConfig: {
        decayCurveStoppingConfig: {useElapsedTime: false},
        medianAutomatedStoppingConfig: {useElapsedTime: false}
      },
      metrics: [{goal: '', metric: ''}],
      parameters: [
        {
          categoricalValueSpec: {values: []},
          childParameterSpecs: [],
          discreteValueSpec: {values: []},
          doubleValueSpec: {maxValue: '', minValue: ''},
          integerValueSpec: {maxValue: '', minValue: ''},
          parameter: '',
          parentCategoricalValues: {values: []},
          parentDiscreteValues: {values: []},
          parentIntValues: {values: []},
          scaleType: '',
          type: ''
        }
      ]
    }
  }
};

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

const url = '{{baseUrl}}/v1/:parent/studies';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"createTime":"","inactiveReason":"","name":"","state":"","studyConfig":{"algorithm":"","automatedStoppingConfig":{"decayCurveStoppingConfig":{"useElapsedTime":false},"medianAutomatedStoppingConfig":{"useElapsedTime":false}},"metrics":[{"goal":"","metric":""}],"parameters":[{"categoricalValueSpec":{"values":[]},"childParameterSpecs":[],"discreteValueSpec":{"values":[]},"doubleValueSpec":{"maxValue":"","minValue":""},"integerValueSpec":{"maxValue":"","minValue":""},"parameter":"","parentCategoricalValues":{"values":[]},"parentDiscreteValues":{"values":[]},"parentIntValues":{"values":[]},"scaleType":"","type":""}]}}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"createTime": @"",
                              @"inactiveReason": @"",
                              @"name": @"",
                              @"state": @"",
                              @"studyConfig": @{ @"algorithm": @"", @"automatedStoppingConfig": @{ @"decayCurveStoppingConfig": @{ @"useElapsedTime": @NO }, @"medianAutomatedStoppingConfig": @{ @"useElapsedTime": @NO } }, @"metrics": @[ @{ @"goal": @"", @"metric": @"" } ], @"parameters": @[ @{ @"categoricalValueSpec": @{ @"values": @[  ] }, @"childParameterSpecs": @[  ], @"discreteValueSpec": @{ @"values": @[  ] }, @"doubleValueSpec": @{ @"maxValue": @"", @"minValue": @"" }, @"integerValueSpec": @{ @"maxValue": @"", @"minValue": @"" }, @"parameter": @"", @"parentCategoricalValues": @{ @"values": @[  ] }, @"parentDiscreteValues": @{ @"values": @[  ] }, @"parentIntValues": @{ @"values": @[  ] }, @"scaleType": @"", @"type": @"" } ] } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:parent/studies" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:parent/studies",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'createTime' => '',
    'inactiveReason' => '',
    'name' => '',
    'state' => '',
    'studyConfig' => [
        'algorithm' => '',
        'automatedStoppingConfig' => [
                'decayCurveStoppingConfig' => [
                                'useElapsedTime' => null
                ],
                'medianAutomatedStoppingConfig' => [
                                'useElapsedTime' => null
                ]
        ],
        'metrics' => [
                [
                                'goal' => '',
                                'metric' => ''
                ]
        ],
        'parameters' => [
                [
                                'categoricalValueSpec' => [
                                                                'values' => [
                                                                                                                                
                                                                ]
                                ],
                                'childParameterSpecs' => [
                                                                
                                ],
                                'discreteValueSpec' => [
                                                                'values' => [
                                                                                                                                
                                                                ]
                                ],
                                'doubleValueSpec' => [
                                                                'maxValue' => '',
                                                                'minValue' => ''
                                ],
                                'integerValueSpec' => [
                                                                'maxValue' => '',
                                                                'minValue' => ''
                                ],
                                'parameter' => '',
                                'parentCategoricalValues' => [
                                                                'values' => [
                                                                                                                                
                                                                ]
                                ],
                                'parentDiscreteValues' => [
                                                                'values' => [
                                                                                                                                
                                                                ]
                                ],
                                'parentIntValues' => [
                                                                'values' => [
                                                                                                                                
                                                                ]
                                ],
                                'scaleType' => '',
                                'type' => ''
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:parent/studies', [
  'body' => '{
  "createTime": "",
  "inactiveReason": "",
  "name": "",
  "state": "",
  "studyConfig": {
    "algorithm": "",
    "automatedStoppingConfig": {
      "decayCurveStoppingConfig": {
        "useElapsedTime": false
      },
      "medianAutomatedStoppingConfig": {
        "useElapsedTime": false
      }
    },
    "metrics": [
      {
        "goal": "",
        "metric": ""
      }
    ],
    "parameters": [
      {
        "categoricalValueSpec": {
          "values": []
        },
        "childParameterSpecs": [],
        "discreteValueSpec": {
          "values": []
        },
        "doubleValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "integerValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "parameter": "",
        "parentCategoricalValues": {
          "values": []
        },
        "parentDiscreteValues": {
          "values": []
        },
        "parentIntValues": {
          "values": []
        },
        "scaleType": "",
        "type": ""
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'createTime' => '',
  'inactiveReason' => '',
  'name' => '',
  'state' => '',
  'studyConfig' => [
    'algorithm' => '',
    'automatedStoppingConfig' => [
        'decayCurveStoppingConfig' => [
                'useElapsedTime' => null
        ],
        'medianAutomatedStoppingConfig' => [
                'useElapsedTime' => null
        ]
    ],
    'metrics' => [
        [
                'goal' => '',
                'metric' => ''
        ]
    ],
    'parameters' => [
        [
                'categoricalValueSpec' => [
                                'values' => [
                                                                
                                ]
                ],
                'childParameterSpecs' => [
                                
                ],
                'discreteValueSpec' => [
                                'values' => [
                                                                
                                ]
                ],
                'doubleValueSpec' => [
                                'maxValue' => '',
                                'minValue' => ''
                ],
                'integerValueSpec' => [
                                'maxValue' => '',
                                'minValue' => ''
                ],
                'parameter' => '',
                'parentCategoricalValues' => [
                                'values' => [
                                                                
                                ]
                ],
                'parentDiscreteValues' => [
                                'values' => [
                                                                
                                ]
                ],
                'parentIntValues' => [
                                'values' => [
                                                                
                                ]
                ],
                'scaleType' => '',
                'type' => ''
        ]
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'createTime' => '',
  'inactiveReason' => '',
  'name' => '',
  'state' => '',
  'studyConfig' => [
    'algorithm' => '',
    'automatedStoppingConfig' => [
        'decayCurveStoppingConfig' => [
                'useElapsedTime' => null
        ],
        'medianAutomatedStoppingConfig' => [
                'useElapsedTime' => null
        ]
    ],
    'metrics' => [
        [
                'goal' => '',
                'metric' => ''
        ]
    ],
    'parameters' => [
        [
                'categoricalValueSpec' => [
                                'values' => [
                                                                
                                ]
                ],
                'childParameterSpecs' => [
                                
                ],
                'discreteValueSpec' => [
                                'values' => [
                                                                
                                ]
                ],
                'doubleValueSpec' => [
                                'maxValue' => '',
                                'minValue' => ''
                ],
                'integerValueSpec' => [
                                'maxValue' => '',
                                'minValue' => ''
                ],
                'parameter' => '',
                'parentCategoricalValues' => [
                                'values' => [
                                                                
                                ]
                ],
                'parentDiscreteValues' => [
                                'values' => [
                                                                
                                ]
                ],
                'parentIntValues' => [
                                'values' => [
                                                                
                                ]
                ],
                'scaleType' => '',
                'type' => ''
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v1/:parent/studies');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:parent/studies' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "createTime": "",
  "inactiveReason": "",
  "name": "",
  "state": "",
  "studyConfig": {
    "algorithm": "",
    "automatedStoppingConfig": {
      "decayCurveStoppingConfig": {
        "useElapsedTime": false
      },
      "medianAutomatedStoppingConfig": {
        "useElapsedTime": false
      }
    },
    "metrics": [
      {
        "goal": "",
        "metric": ""
      }
    ],
    "parameters": [
      {
        "categoricalValueSpec": {
          "values": []
        },
        "childParameterSpecs": [],
        "discreteValueSpec": {
          "values": []
        },
        "doubleValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "integerValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "parameter": "",
        "parentCategoricalValues": {
          "values": []
        },
        "parentDiscreteValues": {
          "values": []
        },
        "parentIntValues": {
          "values": []
        },
        "scaleType": "",
        "type": ""
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:parent/studies' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "createTime": "",
  "inactiveReason": "",
  "name": "",
  "state": "",
  "studyConfig": {
    "algorithm": "",
    "automatedStoppingConfig": {
      "decayCurveStoppingConfig": {
        "useElapsedTime": false
      },
      "medianAutomatedStoppingConfig": {
        "useElapsedTime": false
      }
    },
    "metrics": [
      {
        "goal": "",
        "metric": ""
      }
    ],
    "parameters": [
      {
        "categoricalValueSpec": {
          "values": []
        },
        "childParameterSpecs": [],
        "discreteValueSpec": {
          "values": []
        },
        "doubleValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "integerValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "parameter": "",
        "parentCategoricalValues": {
          "values": []
        },
        "parentDiscreteValues": {
          "values": []
        },
        "parentIntValues": {
          "values": []
        },
        "scaleType": "",
        "type": ""
      }
    ]
  }
}'
import http.client

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

payload = "{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}"

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

conn.request("POST", "/baseUrl/v1/:parent/studies", payload, headers)

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

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

url = "{{baseUrl}}/v1/:parent/studies"

payload = {
    "createTime": "",
    "inactiveReason": "",
    "name": "",
    "state": "",
    "studyConfig": {
        "algorithm": "",
        "automatedStoppingConfig": {
            "decayCurveStoppingConfig": { "useElapsedTime": False },
            "medianAutomatedStoppingConfig": { "useElapsedTime": False }
        },
        "metrics": [
            {
                "goal": "",
                "metric": ""
            }
        ],
        "parameters": [
            {
                "categoricalValueSpec": { "values": [] },
                "childParameterSpecs": [],
                "discreteValueSpec": { "values": [] },
                "doubleValueSpec": {
                    "maxValue": "",
                    "minValue": ""
                },
                "integerValueSpec": {
                    "maxValue": "",
                    "minValue": ""
                },
                "parameter": "",
                "parentCategoricalValues": { "values": [] },
                "parentDiscreteValues": { "values": [] },
                "parentIntValues": { "values": [] },
                "scaleType": "",
                "type": ""
            }
        ]
    }
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1/:parent/studies"

payload <- "{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v1/:parent/studies")

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  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}"

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

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

response = conn.post('/baseUrl/v1/:parent/studies') do |req|
  req.body = "{\n  \"createTime\": \"\",\n  \"inactiveReason\": \"\",\n  \"name\": \"\",\n  \"state\": \"\",\n  \"studyConfig\": {\n    \"algorithm\": \"\",\n    \"automatedStoppingConfig\": {\n      \"decayCurveStoppingConfig\": {\n        \"useElapsedTime\": false\n      },\n      \"medianAutomatedStoppingConfig\": {\n        \"useElapsedTime\": false\n      }\n    },\n    \"metrics\": [\n      {\n        \"goal\": \"\",\n        \"metric\": \"\"\n      }\n    ],\n    \"parameters\": [\n      {\n        \"categoricalValueSpec\": {\n          \"values\": []\n        },\n        \"childParameterSpecs\": [],\n        \"discreteValueSpec\": {\n          \"values\": []\n        },\n        \"doubleValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"integerValueSpec\": {\n          \"maxValue\": \"\",\n          \"minValue\": \"\"\n        },\n        \"parameter\": \"\",\n        \"parentCategoricalValues\": {\n          \"values\": []\n        },\n        \"parentDiscreteValues\": {\n          \"values\": []\n        },\n        \"parentIntValues\": {\n          \"values\": []\n        },\n        \"scaleType\": \"\",\n        \"type\": \"\"\n      }\n    ]\n  }\n}"
end

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

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

    let payload = json!({
        "createTime": "",
        "inactiveReason": "",
        "name": "",
        "state": "",
        "studyConfig": json!({
            "algorithm": "",
            "automatedStoppingConfig": json!({
                "decayCurveStoppingConfig": json!({"useElapsedTime": false}),
                "medianAutomatedStoppingConfig": json!({"useElapsedTime": false})
            }),
            "metrics": (
                json!({
                    "goal": "",
                    "metric": ""
                })
            ),
            "parameters": (
                json!({
                    "categoricalValueSpec": json!({"values": ()}),
                    "childParameterSpecs": (),
                    "discreteValueSpec": json!({"values": ()}),
                    "doubleValueSpec": json!({
                        "maxValue": "",
                        "minValue": ""
                    }),
                    "integerValueSpec": json!({
                        "maxValue": "",
                        "minValue": ""
                    }),
                    "parameter": "",
                    "parentCategoricalValues": json!({"values": ()}),
                    "parentDiscreteValues": json!({"values": ()}),
                    "parentIntValues": json!({"values": ()}),
                    "scaleType": "",
                    "type": ""
                })
            )
        })
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:parent/studies \
  --header 'content-type: application/json' \
  --data '{
  "createTime": "",
  "inactiveReason": "",
  "name": "",
  "state": "",
  "studyConfig": {
    "algorithm": "",
    "automatedStoppingConfig": {
      "decayCurveStoppingConfig": {
        "useElapsedTime": false
      },
      "medianAutomatedStoppingConfig": {
        "useElapsedTime": false
      }
    },
    "metrics": [
      {
        "goal": "",
        "metric": ""
      }
    ],
    "parameters": [
      {
        "categoricalValueSpec": {
          "values": []
        },
        "childParameterSpecs": [],
        "discreteValueSpec": {
          "values": []
        },
        "doubleValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "integerValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "parameter": "",
        "parentCategoricalValues": {
          "values": []
        },
        "parentDiscreteValues": {
          "values": []
        },
        "parentIntValues": {
          "values": []
        },
        "scaleType": "",
        "type": ""
      }
    ]
  }
}'
echo '{
  "createTime": "",
  "inactiveReason": "",
  "name": "",
  "state": "",
  "studyConfig": {
    "algorithm": "",
    "automatedStoppingConfig": {
      "decayCurveStoppingConfig": {
        "useElapsedTime": false
      },
      "medianAutomatedStoppingConfig": {
        "useElapsedTime": false
      }
    },
    "metrics": [
      {
        "goal": "",
        "metric": ""
      }
    ],
    "parameters": [
      {
        "categoricalValueSpec": {
          "values": []
        },
        "childParameterSpecs": [],
        "discreteValueSpec": {
          "values": []
        },
        "doubleValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "integerValueSpec": {
          "maxValue": "",
          "minValue": ""
        },
        "parameter": "",
        "parentCategoricalValues": {
          "values": []
        },
        "parentDiscreteValues": {
          "values": []
        },
        "parentIntValues": {
          "values": []
        },
        "scaleType": "",
        "type": ""
      }
    ]
  }
}' |  \
  http POST {{baseUrl}}/v1/:parent/studies \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "createTime": "",\n  "inactiveReason": "",\n  "name": "",\n  "state": "",\n  "studyConfig": {\n    "algorithm": "",\n    "automatedStoppingConfig": {\n      "decayCurveStoppingConfig": {\n        "useElapsedTime": false\n      },\n      "medianAutomatedStoppingConfig": {\n        "useElapsedTime": false\n      }\n    },\n    "metrics": [\n      {\n        "goal": "",\n        "metric": ""\n      }\n    ],\n    "parameters": [\n      {\n        "categoricalValueSpec": {\n          "values": []\n        },\n        "childParameterSpecs": [],\n        "discreteValueSpec": {\n          "values": []\n        },\n        "doubleValueSpec": {\n          "maxValue": "",\n          "minValue": ""\n        },\n        "integerValueSpec": {\n          "maxValue": "",\n          "minValue": ""\n        },\n        "parameter": "",\n        "parentCategoricalValues": {\n          "values": []\n        },\n        "parentDiscreteValues": {\n          "values": []\n        },\n        "parentIntValues": {\n          "values": []\n        },\n        "scaleType": "",\n        "type": ""\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v1/:parent/studies
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "createTime": "",
  "inactiveReason": "",
  "name": "",
  "state": "",
  "studyConfig": [
    "algorithm": "",
    "automatedStoppingConfig": [
      "decayCurveStoppingConfig": ["useElapsedTime": false],
      "medianAutomatedStoppingConfig": ["useElapsedTime": false]
    ],
    "metrics": [
      [
        "goal": "",
        "metric": ""
      ]
    ],
    "parameters": [
      [
        "categoricalValueSpec": ["values": []],
        "childParameterSpecs": [],
        "discreteValueSpec": ["values": []],
        "doubleValueSpec": [
          "maxValue": "",
          "minValue": ""
        ],
        "integerValueSpec": [
          "maxValue": "",
          "minValue": ""
        ],
        "parameter": "",
        "parentCategoricalValues": ["values": []],
        "parentDiscreteValues": ["values": []],
        "parentIntValues": ["values": []],
        "scaleType": "",
        "type": ""
      ]
    ]
  ]
] as [String : Any]

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

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

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

dataTask.resume()
GET ml.projects.locations.studies.list
{{baseUrl}}/v1/:parent/studies
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/v1/:parent/studies")
require "http/client"

url = "{{baseUrl}}/v1/:parent/studies"

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

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

func main() {

	url := "{{baseUrl}}/v1/:parent/studies"

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

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

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

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

}
GET /baseUrl/v1/:parent/studies HTTP/1.1
Host: example.com

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

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

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

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

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

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

xhr.open('GET', '{{baseUrl}}/v1/:parent/studies');

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

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/studies'};

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

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

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

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

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

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/studies'};

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/studies'};

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

const url = '{{baseUrl}}/v1/:parent/studies';
const options = {method: 'GET'};

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:parent/studies" in

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

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

curl_close($curl);

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

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

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

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

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

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

conn.request("GET", "/baseUrl/v1/:parent/studies")

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

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

url = "{{baseUrl}}/v1/:parent/studies"

response = requests.get(url)

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

url <- "{{baseUrl}}/v1/:parent/studies"

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

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

url = URI("{{baseUrl}}/v1/:parent/studies")

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:parent/studies")! 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 ml.projects.locations.studies.trials.addMeasurement
{{baseUrl}}/v1/:name:addMeasurement
QUERY PARAMS

name
BODY json

{
  "measurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:name:addMeasurement");

struct curl_slist *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  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}");

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

(client/post "{{baseUrl}}/v1/:name:addMeasurement" {:content-type :json
                                                                    :form-params {:measurement {:elapsedTime ""
                                                                                                :metrics [{:metric ""
                                                                                                           :value ""}]
                                                                                                :stepCount ""}}})
require "http/client"

url = "{{baseUrl}}/v1/:name:addMeasurement"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:name:addMeasurement"),
    Content = new StringContent("{\n  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:name:addMeasurement");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1/:name:addMeasurement"

	payload := strings.NewReader("{\n  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v1/:name:addMeasurement HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 151

{
  "measurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:name:addMeasurement")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:name:addMeasurement"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\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  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:name:addMeasurement")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:name:addMeasurement")
  .header("content-type", "application/json")
  .body("{\n  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  measurement: {
    elapsedTime: '',
    metrics: [
      {
        metric: '',
        value: ''
      }
    ],
    stepCount: ''
  }
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:addMeasurement',
  headers: {'content-type': 'application/json'},
  data: {
    measurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''}
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:name:addMeasurement';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"measurement":{"elapsedTime":"","metrics":[{"metric":"","value":""}],"stepCount":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:name:addMeasurement',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "measurement": {\n    "elapsedTime": "",\n    "metrics": [\n      {\n        "metric": "",\n        "value": ""\n      }\n    ],\n    "stepCount": ""\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  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:name:addMeasurement")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:name:addMeasurement',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  measurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''}
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:addMeasurement',
  headers: {'content-type': 'application/json'},
  body: {
    measurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''}
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v1/:name:addMeasurement');

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

req.type('json');
req.send({
  measurement: {
    elapsedTime: '',
    metrics: [
      {
        metric: '',
        value: ''
      }
    ],
    stepCount: ''
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:addMeasurement',
  headers: {'content-type': 'application/json'},
  data: {
    measurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''}
  }
};

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

const url = '{{baseUrl}}/v1/:name:addMeasurement';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"measurement":{"elapsedTime":"","metrics":[{"metric":"","value":""}],"stepCount":""}}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"measurement": @{ @"elapsedTime": @"", @"metrics": @[ @{ @"metric": @"", @"value": @"" } ], @"stepCount": @"" } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:name:addMeasurement" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:name:addMeasurement",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'measurement' => [
        'elapsedTime' => '',
        'metrics' => [
                [
                                'metric' => '',
                                'value' => ''
                ]
        ],
        'stepCount' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:name:addMeasurement', [
  'body' => '{
  "measurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:name:addMeasurement');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'measurement' => [
    'elapsedTime' => '',
    'metrics' => [
        [
                'metric' => '',
                'value' => ''
        ]
    ],
    'stepCount' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'measurement' => [
    'elapsedTime' => '',
    'metrics' => [
        [
                'metric' => '',
                'value' => ''
        ]
    ],
    'stepCount' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v1/:name:addMeasurement');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:name:addMeasurement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "measurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name:addMeasurement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "measurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  }
}'
import http.client

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

payload = "{\n  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}"

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

conn.request("POST", "/baseUrl/v1/:name:addMeasurement", payload, headers)

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

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

url = "{{baseUrl}}/v1/:name:addMeasurement"

payload = { "measurement": {
        "elapsedTime": "",
        "metrics": [
            {
                "metric": "",
                "value": ""
            }
        ],
        "stepCount": ""
    } }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1/:name:addMeasurement"

payload <- "{\n  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}"

encode <- "json"

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

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

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

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  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}"

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

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

response = conn.post('/baseUrl/v1/:name:addMeasurement') do |req|
  req.body = "{\n  \"measurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  }\n}"
end

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

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

    let payload = json!({"measurement": json!({
            "elapsedTime": "",
            "metrics": (
                json!({
                    "metric": "",
                    "value": ""
                })
            ),
            "stepCount": ""
        })});

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:name:addMeasurement \
  --header 'content-type: application/json' \
  --data '{
  "measurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  }
}'
echo '{
  "measurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  }
}' |  \
  http POST {{baseUrl}}/v1/:name:addMeasurement \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "measurement": {\n    "elapsedTime": "",\n    "metrics": [\n      {\n        "metric": "",\n        "value": ""\n      }\n    ],\n    "stepCount": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v1/:name:addMeasurement
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["measurement": [
    "elapsedTime": "",
    "metrics": [
      [
        "metric": "",
        "value": ""
      ]
    ],
    "stepCount": ""
  ]] as [String : Any]

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

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

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

dataTask.resume()
POST ml.projects.locations.studies.trials.checkEarlyStoppingState
{{baseUrl}}/v1/:name:checkEarlyStoppingState
QUERY PARAMS

name
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:name:checkEarlyStoppingState");

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

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

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

(client/post "{{baseUrl}}/v1/:name:checkEarlyStoppingState" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v1/:name:checkEarlyStoppingState"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{}"

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

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

func main() {

	url := "{{baseUrl}}/v1/:name:checkEarlyStoppingState"

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

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

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

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

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

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

}
POST /baseUrl/v1/:name:checkEarlyStoppingState HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:name:checkEarlyStoppingState")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:name:checkEarlyStoppingState")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:name:checkEarlyStoppingState")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:checkEarlyStoppingState',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:name:checkEarlyStoppingState';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:name:checkEarlyStoppingState',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:name:checkEarlyStoppingState")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:name:checkEarlyStoppingState',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:checkEarlyStoppingState',
  headers: {'content-type': 'application/json'},
  body: {},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v1/:name:checkEarlyStoppingState');

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:checkEarlyStoppingState',
  headers: {'content-type': 'application/json'},
  data: {}
};

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

const url = '{{baseUrl}}/v1/:name:checkEarlyStoppingState';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

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

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

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:name:checkEarlyStoppingState" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:name:checkEarlyStoppingState', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:name:checkEarlyStoppingState');
$request->setMethod(HTTP_METH_POST);

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

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

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

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

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:name:checkEarlyStoppingState' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name:checkEarlyStoppingState' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

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

payload = "{}"

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

conn.request("POST", "/baseUrl/v1/:name:checkEarlyStoppingState", payload, headers)

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

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

url = "{{baseUrl}}/v1/:name:checkEarlyStoppingState"

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

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

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

url <- "{{baseUrl}}/v1/:name:checkEarlyStoppingState"

payload <- "{}"

encode <- "json"

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

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

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

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

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

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

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

response = conn.post('/baseUrl/v1/:name:checkEarlyStoppingState') do |req|
  req.body = "{}"
end

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

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

    let payload = json!({});

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:name:checkEarlyStoppingState \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v1/:name:checkEarlyStoppingState \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v1/:name:checkEarlyStoppingState
import Foundation

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

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

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

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

dataTask.resume()
POST ml.projects.locations.studies.trials.complete
{{baseUrl}}/v1/:name:complete
QUERY PARAMS

name
BODY json

{
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "trialInfeasible": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

struct curl_slist *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  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}");

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

(client/post "{{baseUrl}}/v1/:name:complete" {:content-type :json
                                                              :form-params {:finalMeasurement {:elapsedTime ""
                                                                                               :metrics [{:metric ""
                                                                                                          :value ""}]
                                                                                               :stepCount ""}
                                                                            :infeasibleReason ""
                                                                            :trialInfeasible false}})
require "http/client"

url = "{{baseUrl}}/v1/:name:complete"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:name:complete"),
    Content = new StringContent("{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:name:complete");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}")

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

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

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

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

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

}
POST /baseUrl/v1/:name:complete HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 210

{
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "trialInfeasible": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:name:complete")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:name:complete"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:name:complete")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:name:complete")
  .header("content-type", "application/json")
  .body("{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}")
  .asString();
const data = JSON.stringify({
  finalMeasurement: {
    elapsedTime: '',
    metrics: [
      {
        metric: '',
        value: ''
      }
    ],
    stepCount: ''
  },
  infeasibleReason: '',
  trialInfeasible: false
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:complete',
  headers: {'content-type': 'application/json'},
  data: {
    finalMeasurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''},
    infeasibleReason: '',
    trialInfeasible: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:name:complete';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"finalMeasurement":{"elapsedTime":"","metrics":[{"metric":"","value":""}],"stepCount":""},"infeasibleReason":"","trialInfeasible":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:name:complete',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "finalMeasurement": {\n    "elapsedTime": "",\n    "metrics": [\n      {\n        "metric": "",\n        "value": ""\n      }\n    ],\n    "stepCount": ""\n  },\n  "infeasibleReason": "",\n  "trialInfeasible": false\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:name:complete")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:name:complete',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  finalMeasurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''},
  infeasibleReason: '',
  trialInfeasible: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:complete',
  headers: {'content-type': 'application/json'},
  body: {
    finalMeasurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''},
    infeasibleReason: '',
    trialInfeasible: false
  },
  json: true
};

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

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

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

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

req.type('json');
req.send({
  finalMeasurement: {
    elapsedTime: '',
    metrics: [
      {
        metric: '',
        value: ''
      }
    ],
    stepCount: ''
  },
  infeasibleReason: '',
  trialInfeasible: false
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:complete',
  headers: {'content-type': 'application/json'},
  data: {
    finalMeasurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''},
    infeasibleReason: '',
    trialInfeasible: false
  }
};

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

const url = '{{baseUrl}}/v1/:name:complete';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"finalMeasurement":{"elapsedTime":"","metrics":[{"metric":"","value":""}],"stepCount":""},"infeasibleReason":"","trialInfeasible":false}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"finalMeasurement": @{ @"elapsedTime": @"", @"metrics": @[ @{ @"metric": @"", @"value": @"" } ], @"stepCount": @"" },
                              @"infeasibleReason": @"",
                              @"trialInfeasible": @NO };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:name:complete" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:name:complete",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'finalMeasurement' => [
        'elapsedTime' => '',
        'metrics' => [
                [
                                'metric' => '',
                                'value' => ''
                ]
        ],
        'stepCount' => ''
    ],
    'infeasibleReason' => '',
    'trialInfeasible' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:name:complete', [
  'body' => '{
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "trialInfeasible": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'finalMeasurement' => [
    'elapsedTime' => '',
    'metrics' => [
        [
                'metric' => '',
                'value' => ''
        ]
    ],
    'stepCount' => ''
  ],
  'infeasibleReason' => '',
  'trialInfeasible' => null
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'finalMeasurement' => [
    'elapsedTime' => '',
    'metrics' => [
        [
                'metric' => '',
                'value' => ''
        ]
    ],
    'stepCount' => ''
  ],
  'infeasibleReason' => '',
  'trialInfeasible' => null
]));
$request->setRequestUrl('{{baseUrl}}/v1/:name:complete');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:name:complete' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "trialInfeasible": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name:complete' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "trialInfeasible": false
}'
import http.client

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

payload = "{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}"

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

conn.request("POST", "/baseUrl/v1/:name:complete", payload, headers)

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

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

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

payload = {
    "finalMeasurement": {
        "elapsedTime": "",
        "metrics": [
            {
                "metric": "",
                "value": ""
            }
        ],
        "stepCount": ""
    },
    "infeasibleReason": "",
    "trialInfeasible": False
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}"

encode <- "json"

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

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

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

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  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}"

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

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

response = conn.post('/baseUrl/v1/:name:complete') do |req|
  req.body = "{\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"trialInfeasible\": false\n}"
end

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

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

    let payload = json!({
        "finalMeasurement": json!({
            "elapsedTime": "",
            "metrics": (
                json!({
                    "metric": "",
                    "value": ""
                })
            ),
            "stepCount": ""
        }),
        "infeasibleReason": "",
        "trialInfeasible": false
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:name:complete \
  --header 'content-type: application/json' \
  --data '{
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "trialInfeasible": false
}'
echo '{
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "trialInfeasible": false
}' |  \
  http POST {{baseUrl}}/v1/:name:complete \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "finalMeasurement": {\n    "elapsedTime": "",\n    "metrics": [\n      {\n        "metric": "",\n        "value": ""\n      }\n    ],\n    "stepCount": ""\n  },\n  "infeasibleReason": "",\n  "trialInfeasible": false\n}' \
  --output-document \
  - {{baseUrl}}/v1/:name:complete
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "finalMeasurement": [
    "elapsedTime": "",
    "metrics": [
      [
        "metric": "",
        "value": ""
      ]
    ],
    "stepCount": ""
  ],
  "infeasibleReason": "",
  "trialInfeasible": false
] as [String : Any]

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

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

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

dataTask.resume()
POST ml.projects.locations.studies.trials.create
{{baseUrl}}/v1/:parent/trials
QUERY PARAMS

parent
BODY json

{
  "clientId": "",
  "endTime": "",
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "measurements": [
    {}
  ],
  "name": "",
  "parameters": [
    {
      "floatValue": "",
      "intValue": "",
      "parameter": "",
      "stringValue": ""
    }
  ],
  "startTime": "",
  "state": "",
  "trialInfeasible": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

struct curl_slist *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  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}");

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

(client/post "{{baseUrl}}/v1/:parent/trials" {:content-type :json
                                                              :form-params {:clientId ""
                                                                            :endTime ""
                                                                            :finalMeasurement {:elapsedTime ""
                                                                                               :metrics [{:metric ""
                                                                                                          :value ""}]
                                                                                               :stepCount ""}
                                                                            :infeasibleReason ""
                                                                            :measurements [{}]
                                                                            :name ""
                                                                            :parameters [{:floatValue ""
                                                                                          :intValue ""
                                                                                          :parameter ""
                                                                                          :stringValue ""}]
                                                                            :startTime ""
                                                                            :state ""
                                                                            :trialInfeasible false}})
require "http/client"

url = "{{baseUrl}}/v1/:parent/trials"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:parent/trials"),
    Content = new StringContent("{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:parent/trials");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1/:parent/trials"

	payload := strings.NewReader("{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}")

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

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

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

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

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

}
POST /baseUrl/v1/:parent/trials HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 453

{
  "clientId": "",
  "endTime": "",
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "measurements": [
    {}
  ],
  "name": "",
  "parameters": [
    {
      "floatValue": "",
      "intValue": "",
      "parameter": "",
      "stringValue": ""
    }
  ],
  "startTime": "",
  "state": "",
  "trialInfeasible": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:parent/trials")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:parent/trials"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:parent/trials")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:parent/trials")
  .header("content-type", "application/json")
  .body("{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}")
  .asString();
const data = JSON.stringify({
  clientId: '',
  endTime: '',
  finalMeasurement: {
    elapsedTime: '',
    metrics: [
      {
        metric: '',
        value: ''
      }
    ],
    stepCount: ''
  },
  infeasibleReason: '',
  measurements: [
    {}
  ],
  name: '',
  parameters: [
    {
      floatValue: '',
      intValue: '',
      parameter: '',
      stringValue: ''
    }
  ],
  startTime: '',
  state: '',
  trialInfeasible: false
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/trials',
  headers: {'content-type': 'application/json'},
  data: {
    clientId: '',
    endTime: '',
    finalMeasurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''},
    infeasibleReason: '',
    measurements: [{}],
    name: '',
    parameters: [{floatValue: '', intValue: '', parameter: '', stringValue: ''}],
    startTime: '',
    state: '',
    trialInfeasible: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:parent/trials';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clientId":"","endTime":"","finalMeasurement":{"elapsedTime":"","metrics":[{"metric":"","value":""}],"stepCount":""},"infeasibleReason":"","measurements":[{}],"name":"","parameters":[{"floatValue":"","intValue":"","parameter":"","stringValue":""}],"startTime":"","state":"","trialInfeasible":false}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:parent/trials',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clientId": "",\n  "endTime": "",\n  "finalMeasurement": {\n    "elapsedTime": "",\n    "metrics": [\n      {\n        "metric": "",\n        "value": ""\n      }\n    ],\n    "stepCount": ""\n  },\n  "infeasibleReason": "",\n  "measurements": [\n    {}\n  ],\n  "name": "",\n  "parameters": [\n    {\n      "floatValue": "",\n      "intValue": "",\n      "parameter": "",\n      "stringValue": ""\n    }\n  ],\n  "startTime": "",\n  "state": "",\n  "trialInfeasible": false\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:parent/trials")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:parent/trials',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  clientId: '',
  endTime: '',
  finalMeasurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''},
  infeasibleReason: '',
  measurements: [{}],
  name: '',
  parameters: [{floatValue: '', intValue: '', parameter: '', stringValue: ''}],
  startTime: '',
  state: '',
  trialInfeasible: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/trials',
  headers: {'content-type': 'application/json'},
  body: {
    clientId: '',
    endTime: '',
    finalMeasurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''},
    infeasibleReason: '',
    measurements: [{}],
    name: '',
    parameters: [{floatValue: '', intValue: '', parameter: '', stringValue: ''}],
    startTime: '',
    state: '',
    trialInfeasible: false
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v1/:parent/trials');

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

req.type('json');
req.send({
  clientId: '',
  endTime: '',
  finalMeasurement: {
    elapsedTime: '',
    metrics: [
      {
        metric: '',
        value: ''
      }
    ],
    stepCount: ''
  },
  infeasibleReason: '',
  measurements: [
    {}
  ],
  name: '',
  parameters: [
    {
      floatValue: '',
      intValue: '',
      parameter: '',
      stringValue: ''
    }
  ],
  startTime: '',
  state: '',
  trialInfeasible: false
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/trials',
  headers: {'content-type': 'application/json'},
  data: {
    clientId: '',
    endTime: '',
    finalMeasurement: {elapsedTime: '', metrics: [{metric: '', value: ''}], stepCount: ''},
    infeasibleReason: '',
    measurements: [{}],
    name: '',
    parameters: [{floatValue: '', intValue: '', parameter: '', stringValue: ''}],
    startTime: '',
    state: '',
    trialInfeasible: false
  }
};

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

const url = '{{baseUrl}}/v1/:parent/trials';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clientId":"","endTime":"","finalMeasurement":{"elapsedTime":"","metrics":[{"metric":"","value":""}],"stepCount":""},"infeasibleReason":"","measurements":[{}],"name":"","parameters":[{"floatValue":"","intValue":"","parameter":"","stringValue":""}],"startTime":"","state":"","trialInfeasible":false}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"clientId": @"",
                              @"endTime": @"",
                              @"finalMeasurement": @{ @"elapsedTime": @"", @"metrics": @[ @{ @"metric": @"", @"value": @"" } ], @"stepCount": @"" },
                              @"infeasibleReason": @"",
                              @"measurements": @[ @{  } ],
                              @"name": @"",
                              @"parameters": @[ @{ @"floatValue": @"", @"intValue": @"", @"parameter": @"", @"stringValue": @"" } ],
                              @"startTime": @"",
                              @"state": @"",
                              @"trialInfeasible": @NO };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:parent/trials" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:parent/trials",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'clientId' => '',
    'endTime' => '',
    'finalMeasurement' => [
        'elapsedTime' => '',
        'metrics' => [
                [
                                'metric' => '',
                                'value' => ''
                ]
        ],
        'stepCount' => ''
    ],
    'infeasibleReason' => '',
    'measurements' => [
        [
                
        ]
    ],
    'name' => '',
    'parameters' => [
        [
                'floatValue' => '',
                'intValue' => '',
                'parameter' => '',
                'stringValue' => ''
        ]
    ],
    'startTime' => '',
    'state' => '',
    'trialInfeasible' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:parent/trials', [
  'body' => '{
  "clientId": "",
  "endTime": "",
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "measurements": [
    {}
  ],
  "name": "",
  "parameters": [
    {
      "floatValue": "",
      "intValue": "",
      "parameter": "",
      "stringValue": ""
    }
  ],
  "startTime": "",
  "state": "",
  "trialInfeasible": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clientId' => '',
  'endTime' => '',
  'finalMeasurement' => [
    'elapsedTime' => '',
    'metrics' => [
        [
                'metric' => '',
                'value' => ''
        ]
    ],
    'stepCount' => ''
  ],
  'infeasibleReason' => '',
  'measurements' => [
    [
        
    ]
  ],
  'name' => '',
  'parameters' => [
    [
        'floatValue' => '',
        'intValue' => '',
        'parameter' => '',
        'stringValue' => ''
    ]
  ],
  'startTime' => '',
  'state' => '',
  'trialInfeasible' => null
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clientId' => '',
  'endTime' => '',
  'finalMeasurement' => [
    'elapsedTime' => '',
    'metrics' => [
        [
                'metric' => '',
                'value' => ''
        ]
    ],
    'stepCount' => ''
  ],
  'infeasibleReason' => '',
  'measurements' => [
    [
        
    ]
  ],
  'name' => '',
  'parameters' => [
    [
        'floatValue' => '',
        'intValue' => '',
        'parameter' => '',
        'stringValue' => ''
    ]
  ],
  'startTime' => '',
  'state' => '',
  'trialInfeasible' => null
]));
$request->setRequestUrl('{{baseUrl}}/v1/:parent/trials');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:parent/trials' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clientId": "",
  "endTime": "",
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "measurements": [
    {}
  ],
  "name": "",
  "parameters": [
    {
      "floatValue": "",
      "intValue": "",
      "parameter": "",
      "stringValue": ""
    }
  ],
  "startTime": "",
  "state": "",
  "trialInfeasible": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:parent/trials' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clientId": "",
  "endTime": "",
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "measurements": [
    {}
  ],
  "name": "",
  "parameters": [
    {
      "floatValue": "",
      "intValue": "",
      "parameter": "",
      "stringValue": ""
    }
  ],
  "startTime": "",
  "state": "",
  "trialInfeasible": false
}'
import http.client

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

payload = "{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}"

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

conn.request("POST", "/baseUrl/v1/:parent/trials", payload, headers)

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

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

url = "{{baseUrl}}/v1/:parent/trials"

payload = {
    "clientId": "",
    "endTime": "",
    "finalMeasurement": {
        "elapsedTime": "",
        "metrics": [
            {
                "metric": "",
                "value": ""
            }
        ],
        "stepCount": ""
    },
    "infeasibleReason": "",
    "measurements": [{}],
    "name": "",
    "parameters": [
        {
            "floatValue": "",
            "intValue": "",
            "parameter": "",
            "stringValue": ""
        }
    ],
    "startTime": "",
    "state": "",
    "trialInfeasible": False
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1/:parent/trials"

payload <- "{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v1/:parent/trials")

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  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}"

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

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

response = conn.post('/baseUrl/v1/:parent/trials') do |req|
  req.body = "{\n  \"clientId\": \"\",\n  \"endTime\": \"\",\n  \"finalMeasurement\": {\n    \"elapsedTime\": \"\",\n    \"metrics\": [\n      {\n        \"metric\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"stepCount\": \"\"\n  },\n  \"infeasibleReason\": \"\",\n  \"measurements\": [\n    {}\n  ],\n  \"name\": \"\",\n  \"parameters\": [\n    {\n      \"floatValue\": \"\",\n      \"intValue\": \"\",\n      \"parameter\": \"\",\n      \"stringValue\": \"\"\n    }\n  ],\n  \"startTime\": \"\",\n  \"state\": \"\",\n  \"trialInfeasible\": false\n}"
end

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

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

    let payload = json!({
        "clientId": "",
        "endTime": "",
        "finalMeasurement": json!({
            "elapsedTime": "",
            "metrics": (
                json!({
                    "metric": "",
                    "value": ""
                })
            ),
            "stepCount": ""
        }),
        "infeasibleReason": "",
        "measurements": (json!({})),
        "name": "",
        "parameters": (
            json!({
                "floatValue": "",
                "intValue": "",
                "parameter": "",
                "stringValue": ""
            })
        ),
        "startTime": "",
        "state": "",
        "trialInfeasible": false
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:parent/trials \
  --header 'content-type: application/json' \
  --data '{
  "clientId": "",
  "endTime": "",
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "measurements": [
    {}
  ],
  "name": "",
  "parameters": [
    {
      "floatValue": "",
      "intValue": "",
      "parameter": "",
      "stringValue": ""
    }
  ],
  "startTime": "",
  "state": "",
  "trialInfeasible": false
}'
echo '{
  "clientId": "",
  "endTime": "",
  "finalMeasurement": {
    "elapsedTime": "",
    "metrics": [
      {
        "metric": "",
        "value": ""
      }
    ],
    "stepCount": ""
  },
  "infeasibleReason": "",
  "measurements": [
    {}
  ],
  "name": "",
  "parameters": [
    {
      "floatValue": "",
      "intValue": "",
      "parameter": "",
      "stringValue": ""
    }
  ],
  "startTime": "",
  "state": "",
  "trialInfeasible": false
}' |  \
  http POST {{baseUrl}}/v1/:parent/trials \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clientId": "",\n  "endTime": "",\n  "finalMeasurement": {\n    "elapsedTime": "",\n    "metrics": [\n      {\n        "metric": "",\n        "value": ""\n      }\n    ],\n    "stepCount": ""\n  },\n  "infeasibleReason": "",\n  "measurements": [\n    {}\n  ],\n  "name": "",\n  "parameters": [\n    {\n      "floatValue": "",\n      "intValue": "",\n      "parameter": "",\n      "stringValue": ""\n    }\n  ],\n  "startTime": "",\n  "state": "",\n  "trialInfeasible": false\n}' \
  --output-document \
  - {{baseUrl}}/v1/:parent/trials
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clientId": "",
  "endTime": "",
  "finalMeasurement": [
    "elapsedTime": "",
    "metrics": [
      [
        "metric": "",
        "value": ""
      ]
    ],
    "stepCount": ""
  ],
  "infeasibleReason": "",
  "measurements": [[]],
  "name": "",
  "parameters": [
    [
      "floatValue": "",
      "intValue": "",
      "parameter": "",
      "stringValue": ""
    ]
  ],
  "startTime": "",
  "state": "",
  "trialInfeasible": false
] as [String : Any]

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

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

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

dataTask.resume()
GET ml.projects.locations.studies.trials.list
{{baseUrl}}/v1/:parent/trials
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/v1/:parent/trials")
require "http/client"

url = "{{baseUrl}}/v1/:parent/trials"

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

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

func main() {

	url := "{{baseUrl}}/v1/:parent/trials"

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

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

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

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

}
GET /baseUrl/v1/:parent/trials HTTP/1.1
Host: example.com

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

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

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

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

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

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

xhr.open('GET', '{{baseUrl}}/v1/:parent/trials');

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

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/trials'};

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

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

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

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

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

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/trials'};

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/trials'};

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

const url = '{{baseUrl}}/v1/:parent/trials';
const options = {method: 'GET'};

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:parent/trials" in

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

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

curl_close($curl);

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

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

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

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

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

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

conn.request("GET", "/baseUrl/v1/:parent/trials")

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

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

url = "{{baseUrl}}/v1/:parent/trials"

response = requests.get(url)

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

url <- "{{baseUrl}}/v1/:parent/trials"

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

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

url = URI("{{baseUrl}}/v1/:parent/trials")

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:parent/trials")! 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 ml.projects.locations.studies.trials.listOptimalTrials
{{baseUrl}}/v1/:parent/trials:listOptimalTrials
QUERY PARAMS

parent
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:parent/trials:listOptimalTrials");

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

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

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

(client/post "{{baseUrl}}/v1/:parent/trials:listOptimalTrials" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v1/:parent/trials:listOptimalTrials"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{}"

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

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

func main() {

	url := "{{baseUrl}}/v1/:parent/trials:listOptimalTrials"

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

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

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

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

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

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

}
POST /baseUrl/v1/:parent/trials:listOptimalTrials HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:parent/trials:listOptimalTrials")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:parent/trials:listOptimalTrials")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:parent/trials:listOptimalTrials")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/trials:listOptimalTrials',
  headers: {'content-type': 'application/json'},
  data: {}
};

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

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:parent/trials:listOptimalTrials',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:parent/trials:listOptimalTrials")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:parent/trials:listOptimalTrials',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/trials:listOptimalTrials',
  headers: {'content-type': 'application/json'},
  body: {},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v1/:parent/trials:listOptimalTrials');

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/trials:listOptimalTrials',
  headers: {'content-type': 'application/json'},
  data: {}
};

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

const url = '{{baseUrl}}/v1/:parent/trials:listOptimalTrials';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

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

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

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:parent/trials:listOptimalTrials" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:parent/trials:listOptimalTrials', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/v1/:parent/trials:listOptimalTrials');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:parent/trials:listOptimalTrials' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:parent/trials:listOptimalTrials' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

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

payload = "{}"

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

conn.request("POST", "/baseUrl/v1/:parent/trials:listOptimalTrials", payload, headers)

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

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

url = "{{baseUrl}}/v1/:parent/trials:listOptimalTrials"

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

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

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

url <- "{{baseUrl}}/v1/:parent/trials:listOptimalTrials"

payload <- "{}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v1/:parent/trials:listOptimalTrials")

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

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

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

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

response = conn.post('/baseUrl/v1/:parent/trials:listOptimalTrials') do |req|
  req.body = "{}"
end

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

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

    let payload = json!({});

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:parent/trials:listOptimalTrials \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v1/:parent/trials:listOptimalTrials \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v1/:parent/trials:listOptimalTrials
import Foundation

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

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

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

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

dataTask.resume()
POST ml.projects.locations.studies.trials.stop
{{baseUrl}}/v1/:name:stop
QUERY PARAMS

name
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:name:stop");

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

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

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

(client/post "{{baseUrl}}/v1/:name:stop" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v1/:name:stop"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{}"

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

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

func main() {

	url := "{{baseUrl}}/v1/:name:stop"

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

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

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

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

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

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

}
POST /baseUrl/v1/:name:stop HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:name:stop")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:name:stop")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:name:stop")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:stop',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:name:stop';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:name:stop',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:name:stop")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:name:stop',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:stop',
  headers: {'content-type': 'application/json'},
  body: {},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v1/:name:stop');

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:stop',
  headers: {'content-type': 'application/json'},
  data: {}
};

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

const url = '{{baseUrl}}/v1/:name:stop';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

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

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

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:name:stop" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:name:stop', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:name:stop');
$request->setMethod(HTTP_METH_POST);

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

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

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

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

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:name:stop' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name:stop' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

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

payload = "{}"

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

conn.request("POST", "/baseUrl/v1/:name:stop", payload, headers)

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

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

url = "{{baseUrl}}/v1/:name:stop"

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

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

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

url <- "{{baseUrl}}/v1/:name:stop"

payload <- "{}"

encode <- "json"

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

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

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

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

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

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

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

response = conn.post('/baseUrl/v1/:name:stop') do |req|
  req.body = "{}"
end

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

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

    let payload = json!({});

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:name:stop \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v1/:name:stop \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v1/:name:stop
import Foundation

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

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

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

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

dataTask.resume()
POST ml.projects.locations.studies.trials.suggest
{{baseUrl}}/v1/:parent/trials:suggest
QUERY PARAMS

parent
BODY json

{
  "clientId": "",
  "suggestionCount": 0
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:parent/trials:suggest");

struct curl_slist *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  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}");

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

(client/post "{{baseUrl}}/v1/:parent/trials:suggest" {:content-type :json
                                                                      :form-params {:clientId ""
                                                                                    :suggestionCount 0}})
require "http/client"

url = "{{baseUrl}}/v1/:parent/trials:suggest"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}"

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

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

func main() {

	url := "{{baseUrl}}/v1/:parent/trials:suggest"

	payload := strings.NewReader("{\n  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}")

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

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

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

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

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

}
POST /baseUrl/v1/:parent/trials:suggest HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 44

{
  "clientId": "",
  "suggestionCount": 0
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:parent/trials:suggest")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:parent/trials:suggest")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:parent/trials:suggest")
  .header("content-type", "application/json")
  .body("{\n  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}")
  .asString();
const data = JSON.stringify({
  clientId: '',
  suggestionCount: 0
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/trials:suggest',
  headers: {'content-type': 'application/json'},
  data: {clientId: '', suggestionCount: 0}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:parent/trials:suggest';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clientId":"","suggestionCount":0}'
};

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

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:parent/trials:suggest")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:parent/trials:suggest',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({clientId: '', suggestionCount: 0}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/trials:suggest',
  headers: {'content-type': 'application/json'},
  body: {clientId: '', suggestionCount: 0},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v1/:parent/trials:suggest');

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

req.type('json');
req.send({
  clientId: '',
  suggestionCount: 0
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/trials:suggest',
  headers: {'content-type': 'application/json'},
  data: {clientId: '', suggestionCount: 0}
};

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

const url = '{{baseUrl}}/v1/:parent/trials:suggest';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clientId":"","suggestionCount":0}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"clientId": @"",
                              @"suggestionCount": @0 };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1/:parent/trials:suggest" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:parent/trials:suggest",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'clientId' => '',
    'suggestionCount' => 0
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:parent/trials:suggest', [
  'body' => '{
  "clientId": "",
  "suggestionCount": 0
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clientId' => '',
  'suggestionCount' => 0
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clientId' => '',
  'suggestionCount' => 0
]));
$request->setRequestUrl('{{baseUrl}}/v1/:parent/trials:suggest');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:parent/trials:suggest' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clientId": "",
  "suggestionCount": 0
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:parent/trials:suggest' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clientId": "",
  "suggestionCount": 0
}'
import http.client

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

payload = "{\n  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}"

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

conn.request("POST", "/baseUrl/v1/:parent/trials:suggest", payload, headers)

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

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

url = "{{baseUrl}}/v1/:parent/trials:suggest"

payload = {
    "clientId": "",
    "suggestionCount": 0
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1/:parent/trials:suggest"

payload <- "{\n  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v1/:parent/trials:suggest")

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  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}"

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

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

response = conn.post('/baseUrl/v1/:parent/trials:suggest') do |req|
  req.body = "{\n  \"clientId\": \"\",\n  \"suggestionCount\": 0\n}"
end

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

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

    let payload = json!({
        "clientId": "",
        "suggestionCount": 0
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:parent/trials:suggest \
  --header 'content-type: application/json' \
  --data '{
  "clientId": "",
  "suggestionCount": 0
}'
echo '{
  "clientId": "",
  "suggestionCount": 0
}' |  \
  http POST {{baseUrl}}/v1/:parent/trials:suggest \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clientId": "",\n  "suggestionCount": 0\n}' \
  --output-document \
  - {{baseUrl}}/v1/:parent/trials:suggest
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clientId": "",
  "suggestionCount": 0
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:parent/trials:suggest")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ml.projects.models.create
{{baseUrl}}/v1/:parent/models
QUERY PARAMS

parent
BODY json

{
  "defaultVersion": {
    "acceleratorConfig": {
      "count": "",
      "type": ""
    },
    "autoScaling": {
      "maxNodes": 0,
      "metrics": [
        {
          "name": "",
          "target": 0
        }
      ],
      "minNodes": 0
    },
    "container": {
      "args": [],
      "command": [],
      "env": [
        {
          "name": "",
          "value": ""
        }
      ],
      "image": "",
      "ports": [
        {
          "containerPort": 0
        }
      ]
    },
    "createTime": "",
    "deploymentUri": "",
    "description": "",
    "errorMessage": "",
    "etag": "",
    "explanationConfig": {
      "integratedGradientsAttribution": {
        "numIntegralSteps": 0
      },
      "sampledShapleyAttribution": {
        "numPaths": 0
      },
      "xraiAttribution": {
        "numIntegralSteps": 0
      }
    },
    "framework": "",
    "isDefault": false,
    "labels": {},
    "lastMigrationModelId": "",
    "lastMigrationTime": "",
    "lastUseTime": "",
    "machineType": "",
    "manualScaling": {
      "nodes": 0
    },
    "name": "",
    "packageUris": [],
    "predictionClass": "",
    "pythonVersion": "",
    "requestLoggingConfig": {
      "bigqueryTableName": "",
      "samplingPercentage": ""
    },
    "routes": {
      "health": "",
      "predict": ""
    },
    "runtimeVersion": "",
    "serviceAccount": "",
    "state": ""
  },
  "description": "",
  "etag": "",
  "labels": {},
  "name": "",
  "onlinePredictionConsoleLogging": false,
  "onlinePredictionLogging": false,
  "regions": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:parent/models");

struct curl_slist *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  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1/:parent/models" {:content-type :json
                                                              :form-params {:defaultVersion {:acceleratorConfig {:count ""
                                                                                                                 :type ""}
                                                                                             :autoScaling {:maxNodes 0
                                                                                                           :metrics [{:name ""
                                                                                                                      :target 0}]
                                                                                                           :minNodes 0}
                                                                                             :container {:args []
                                                                                                         :command []
                                                                                                         :env [{:name ""
                                                                                                                :value ""}]
                                                                                                         :image ""
                                                                                                         :ports [{:containerPort 0}]}
                                                                                             :createTime ""
                                                                                             :deploymentUri ""
                                                                                             :description ""
                                                                                             :errorMessage ""
                                                                                             :etag ""
                                                                                             :explanationConfig {:integratedGradientsAttribution {:numIntegralSteps 0}
                                                                                                                 :sampledShapleyAttribution {:numPaths 0}
                                                                                                                 :xraiAttribution {:numIntegralSteps 0}}
                                                                                             :framework ""
                                                                                             :isDefault false
                                                                                             :labels {}
                                                                                             :lastMigrationModelId ""
                                                                                             :lastMigrationTime ""
                                                                                             :lastUseTime ""
                                                                                             :machineType ""
                                                                                             :manualScaling {:nodes 0}
                                                                                             :name ""
                                                                                             :packageUris []
                                                                                             :predictionClass ""
                                                                                             :pythonVersion ""
                                                                                             :requestLoggingConfig {:bigqueryTableName ""
                                                                                                                    :samplingPercentage ""}
                                                                                             :routes {:health ""
                                                                                                      :predict ""}
                                                                                             :runtimeVersion ""
                                                                                             :serviceAccount ""
                                                                                             :state ""}
                                                                            :description ""
                                                                            :etag ""
                                                                            :labels {}
                                                                            :name ""
                                                                            :onlinePredictionConsoleLogging false
                                                                            :onlinePredictionLogging false
                                                                            :regions []}})
require "http/client"

url = "{{baseUrl}}/v1/:parent/models"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:parent/models"),
    Content = new StringContent("{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:parent/models");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:parent/models"

	payload := strings.NewReader("{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v1/:parent/models HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1563

{
  "defaultVersion": {
    "acceleratorConfig": {
      "count": "",
      "type": ""
    },
    "autoScaling": {
      "maxNodes": 0,
      "metrics": [
        {
          "name": "",
          "target": 0
        }
      ],
      "minNodes": 0
    },
    "container": {
      "args": [],
      "command": [],
      "env": [
        {
          "name": "",
          "value": ""
        }
      ],
      "image": "",
      "ports": [
        {
          "containerPort": 0
        }
      ]
    },
    "createTime": "",
    "deploymentUri": "",
    "description": "",
    "errorMessage": "",
    "etag": "",
    "explanationConfig": {
      "integratedGradientsAttribution": {
        "numIntegralSteps": 0
      },
      "sampledShapleyAttribution": {
        "numPaths": 0
      },
      "xraiAttribution": {
        "numIntegralSteps": 0
      }
    },
    "framework": "",
    "isDefault": false,
    "labels": {},
    "lastMigrationModelId": "",
    "lastMigrationTime": "",
    "lastUseTime": "",
    "machineType": "",
    "manualScaling": {
      "nodes": 0
    },
    "name": "",
    "packageUris": [],
    "predictionClass": "",
    "pythonVersion": "",
    "requestLoggingConfig": {
      "bigqueryTableName": "",
      "samplingPercentage": ""
    },
    "routes": {
      "health": "",
      "predict": ""
    },
    "runtimeVersion": "",
    "serviceAccount": "",
    "state": ""
  },
  "description": "",
  "etag": "",
  "labels": {},
  "name": "",
  "onlinePredictionConsoleLogging": false,
  "onlinePredictionLogging": false,
  "regions": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:parent/models")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:parent/models"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:parent/models")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:parent/models")
  .header("content-type", "application/json")
  .body("{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}")
  .asString();
const data = JSON.stringify({
  defaultVersion: {
    acceleratorConfig: {
      count: '',
      type: ''
    },
    autoScaling: {
      maxNodes: 0,
      metrics: [
        {
          name: '',
          target: 0
        }
      ],
      minNodes: 0
    },
    container: {
      args: [],
      command: [],
      env: [
        {
          name: '',
          value: ''
        }
      ],
      image: '',
      ports: [
        {
          containerPort: 0
        }
      ]
    },
    createTime: '',
    deploymentUri: '',
    description: '',
    errorMessage: '',
    etag: '',
    explanationConfig: {
      integratedGradientsAttribution: {
        numIntegralSteps: 0
      },
      sampledShapleyAttribution: {
        numPaths: 0
      },
      xraiAttribution: {
        numIntegralSteps: 0
      }
    },
    framework: '',
    isDefault: false,
    labels: {},
    lastMigrationModelId: '',
    lastMigrationTime: '',
    lastUseTime: '',
    machineType: '',
    manualScaling: {
      nodes: 0
    },
    name: '',
    packageUris: [],
    predictionClass: '',
    pythonVersion: '',
    requestLoggingConfig: {
      bigqueryTableName: '',
      samplingPercentage: ''
    },
    routes: {
      health: '',
      predict: ''
    },
    runtimeVersion: '',
    serviceAccount: '',
    state: ''
  },
  description: '',
  etag: '',
  labels: {},
  name: '',
  onlinePredictionConsoleLogging: false,
  onlinePredictionLogging: false,
  regions: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1/:parent/models');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/models',
  headers: {'content-type': 'application/json'},
  data: {
    defaultVersion: {
      acceleratorConfig: {count: '', type: ''},
      autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
      container: {
        args: [],
        command: [],
        env: [{name: '', value: ''}],
        image: '',
        ports: [{containerPort: 0}]
      },
      createTime: '',
      deploymentUri: '',
      description: '',
      errorMessage: '',
      etag: '',
      explanationConfig: {
        integratedGradientsAttribution: {numIntegralSteps: 0},
        sampledShapleyAttribution: {numPaths: 0},
        xraiAttribution: {numIntegralSteps: 0}
      },
      framework: '',
      isDefault: false,
      labels: {},
      lastMigrationModelId: '',
      lastMigrationTime: '',
      lastUseTime: '',
      machineType: '',
      manualScaling: {nodes: 0},
      name: '',
      packageUris: [],
      predictionClass: '',
      pythonVersion: '',
      requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
      routes: {health: '', predict: ''},
      runtimeVersion: '',
      serviceAccount: '',
      state: ''
    },
    description: '',
    etag: '',
    labels: {},
    name: '',
    onlinePredictionConsoleLogging: false,
    onlinePredictionLogging: false,
    regions: []
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:parent/models';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"defaultVersion":{"acceleratorConfig":{"count":"","type":""},"autoScaling":{"maxNodes":0,"metrics":[{"name":"","target":0}],"minNodes":0},"container":{"args":[],"command":[],"env":[{"name":"","value":""}],"image":"","ports":[{"containerPort":0}]},"createTime":"","deploymentUri":"","description":"","errorMessage":"","etag":"","explanationConfig":{"integratedGradientsAttribution":{"numIntegralSteps":0},"sampledShapleyAttribution":{"numPaths":0},"xraiAttribution":{"numIntegralSteps":0}},"framework":"","isDefault":false,"labels":{},"lastMigrationModelId":"","lastMigrationTime":"","lastUseTime":"","machineType":"","manualScaling":{"nodes":0},"name":"","packageUris":[],"predictionClass":"","pythonVersion":"","requestLoggingConfig":{"bigqueryTableName":"","samplingPercentage":""},"routes":{"health":"","predict":""},"runtimeVersion":"","serviceAccount":"","state":""},"description":"","etag":"","labels":{},"name":"","onlinePredictionConsoleLogging":false,"onlinePredictionLogging":false,"regions":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:parent/models',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "defaultVersion": {\n    "acceleratorConfig": {\n      "count": "",\n      "type": ""\n    },\n    "autoScaling": {\n      "maxNodes": 0,\n      "metrics": [\n        {\n          "name": "",\n          "target": 0\n        }\n      ],\n      "minNodes": 0\n    },\n    "container": {\n      "args": [],\n      "command": [],\n      "env": [\n        {\n          "name": "",\n          "value": ""\n        }\n      ],\n      "image": "",\n      "ports": [\n        {\n          "containerPort": 0\n        }\n      ]\n    },\n    "createTime": "",\n    "deploymentUri": "",\n    "description": "",\n    "errorMessage": "",\n    "etag": "",\n    "explanationConfig": {\n      "integratedGradientsAttribution": {\n        "numIntegralSteps": 0\n      },\n      "sampledShapleyAttribution": {\n        "numPaths": 0\n      },\n      "xraiAttribution": {\n        "numIntegralSteps": 0\n      }\n    },\n    "framework": "",\n    "isDefault": false,\n    "labels": {},\n    "lastMigrationModelId": "",\n    "lastMigrationTime": "",\n    "lastUseTime": "",\n    "machineType": "",\n    "manualScaling": {\n      "nodes": 0\n    },\n    "name": "",\n    "packageUris": [],\n    "predictionClass": "",\n    "pythonVersion": "",\n    "requestLoggingConfig": {\n      "bigqueryTableName": "",\n      "samplingPercentage": ""\n    },\n    "routes": {\n      "health": "",\n      "predict": ""\n    },\n    "runtimeVersion": "",\n    "serviceAccount": "",\n    "state": ""\n  },\n  "description": "",\n  "etag": "",\n  "labels": {},\n  "name": "",\n  "onlinePredictionConsoleLogging": false,\n  "onlinePredictionLogging": false,\n  "regions": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:parent/models")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:parent/models',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  defaultVersion: {
    acceleratorConfig: {count: '', type: ''},
    autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
    container: {
      args: [],
      command: [],
      env: [{name: '', value: ''}],
      image: '',
      ports: [{containerPort: 0}]
    },
    createTime: '',
    deploymentUri: '',
    description: '',
    errorMessage: '',
    etag: '',
    explanationConfig: {
      integratedGradientsAttribution: {numIntegralSteps: 0},
      sampledShapleyAttribution: {numPaths: 0},
      xraiAttribution: {numIntegralSteps: 0}
    },
    framework: '',
    isDefault: false,
    labels: {},
    lastMigrationModelId: '',
    lastMigrationTime: '',
    lastUseTime: '',
    machineType: '',
    manualScaling: {nodes: 0},
    name: '',
    packageUris: [],
    predictionClass: '',
    pythonVersion: '',
    requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
    routes: {health: '', predict: ''},
    runtimeVersion: '',
    serviceAccount: '',
    state: ''
  },
  description: '',
  etag: '',
  labels: {},
  name: '',
  onlinePredictionConsoleLogging: false,
  onlinePredictionLogging: false,
  regions: []
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/models',
  headers: {'content-type': 'application/json'},
  body: {
    defaultVersion: {
      acceleratorConfig: {count: '', type: ''},
      autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
      container: {
        args: [],
        command: [],
        env: [{name: '', value: ''}],
        image: '',
        ports: [{containerPort: 0}]
      },
      createTime: '',
      deploymentUri: '',
      description: '',
      errorMessage: '',
      etag: '',
      explanationConfig: {
        integratedGradientsAttribution: {numIntegralSteps: 0},
        sampledShapleyAttribution: {numPaths: 0},
        xraiAttribution: {numIntegralSteps: 0}
      },
      framework: '',
      isDefault: false,
      labels: {},
      lastMigrationModelId: '',
      lastMigrationTime: '',
      lastUseTime: '',
      machineType: '',
      manualScaling: {nodes: 0},
      name: '',
      packageUris: [],
      predictionClass: '',
      pythonVersion: '',
      requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
      routes: {health: '', predict: ''},
      runtimeVersion: '',
      serviceAccount: '',
      state: ''
    },
    description: '',
    etag: '',
    labels: {},
    name: '',
    onlinePredictionConsoleLogging: false,
    onlinePredictionLogging: false,
    regions: []
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v1/:parent/models');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  defaultVersion: {
    acceleratorConfig: {
      count: '',
      type: ''
    },
    autoScaling: {
      maxNodes: 0,
      metrics: [
        {
          name: '',
          target: 0
        }
      ],
      minNodes: 0
    },
    container: {
      args: [],
      command: [],
      env: [
        {
          name: '',
          value: ''
        }
      ],
      image: '',
      ports: [
        {
          containerPort: 0
        }
      ]
    },
    createTime: '',
    deploymentUri: '',
    description: '',
    errorMessage: '',
    etag: '',
    explanationConfig: {
      integratedGradientsAttribution: {
        numIntegralSteps: 0
      },
      sampledShapleyAttribution: {
        numPaths: 0
      },
      xraiAttribution: {
        numIntegralSteps: 0
      }
    },
    framework: '',
    isDefault: false,
    labels: {},
    lastMigrationModelId: '',
    lastMigrationTime: '',
    lastUseTime: '',
    machineType: '',
    manualScaling: {
      nodes: 0
    },
    name: '',
    packageUris: [],
    predictionClass: '',
    pythonVersion: '',
    requestLoggingConfig: {
      bigqueryTableName: '',
      samplingPercentage: ''
    },
    routes: {
      health: '',
      predict: ''
    },
    runtimeVersion: '',
    serviceAccount: '',
    state: ''
  },
  description: '',
  etag: '',
  labels: {},
  name: '',
  onlinePredictionConsoleLogging: false,
  onlinePredictionLogging: false,
  regions: []
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/models',
  headers: {'content-type': 'application/json'},
  data: {
    defaultVersion: {
      acceleratorConfig: {count: '', type: ''},
      autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
      container: {
        args: [],
        command: [],
        env: [{name: '', value: ''}],
        image: '',
        ports: [{containerPort: 0}]
      },
      createTime: '',
      deploymentUri: '',
      description: '',
      errorMessage: '',
      etag: '',
      explanationConfig: {
        integratedGradientsAttribution: {numIntegralSteps: 0},
        sampledShapleyAttribution: {numPaths: 0},
        xraiAttribution: {numIntegralSteps: 0}
      },
      framework: '',
      isDefault: false,
      labels: {},
      lastMigrationModelId: '',
      lastMigrationTime: '',
      lastUseTime: '',
      machineType: '',
      manualScaling: {nodes: 0},
      name: '',
      packageUris: [],
      predictionClass: '',
      pythonVersion: '',
      requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
      routes: {health: '', predict: ''},
      runtimeVersion: '',
      serviceAccount: '',
      state: ''
    },
    description: '',
    etag: '',
    labels: {},
    name: '',
    onlinePredictionConsoleLogging: false,
    onlinePredictionLogging: false,
    regions: []
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:parent/models';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"defaultVersion":{"acceleratorConfig":{"count":"","type":""},"autoScaling":{"maxNodes":0,"metrics":[{"name":"","target":0}],"minNodes":0},"container":{"args":[],"command":[],"env":[{"name":"","value":""}],"image":"","ports":[{"containerPort":0}]},"createTime":"","deploymentUri":"","description":"","errorMessage":"","etag":"","explanationConfig":{"integratedGradientsAttribution":{"numIntegralSteps":0},"sampledShapleyAttribution":{"numPaths":0},"xraiAttribution":{"numIntegralSteps":0}},"framework":"","isDefault":false,"labels":{},"lastMigrationModelId":"","lastMigrationTime":"","lastUseTime":"","machineType":"","manualScaling":{"nodes":0},"name":"","packageUris":[],"predictionClass":"","pythonVersion":"","requestLoggingConfig":{"bigqueryTableName":"","samplingPercentage":""},"routes":{"health":"","predict":""},"runtimeVersion":"","serviceAccount":"","state":""},"description":"","etag":"","labels":{},"name":"","onlinePredictionConsoleLogging":false,"onlinePredictionLogging":false,"regions":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"defaultVersion": @{ @"acceleratorConfig": @{ @"count": @"", @"type": @"" }, @"autoScaling": @{ @"maxNodes": @0, @"metrics": @[ @{ @"name": @"", @"target": @0 } ], @"minNodes": @0 }, @"container": @{ @"args": @[  ], @"command": @[  ], @"env": @[ @{ @"name": @"", @"value": @"" } ], @"image": @"", @"ports": @[ @{ @"containerPort": @0 } ] }, @"createTime": @"", @"deploymentUri": @"", @"description": @"", @"errorMessage": @"", @"etag": @"", @"explanationConfig": @{ @"integratedGradientsAttribution": @{ @"numIntegralSteps": @0 }, @"sampledShapleyAttribution": @{ @"numPaths": @0 }, @"xraiAttribution": @{ @"numIntegralSteps": @0 } }, @"framework": @"", @"isDefault": @NO, @"labels": @{  }, @"lastMigrationModelId": @"", @"lastMigrationTime": @"", @"lastUseTime": @"", @"machineType": @"", @"manualScaling": @{ @"nodes": @0 }, @"name": @"", @"packageUris": @[  ], @"predictionClass": @"", @"pythonVersion": @"", @"requestLoggingConfig": @{ @"bigqueryTableName": @"", @"samplingPercentage": @"" }, @"routes": @{ @"health": @"", @"predict": @"" }, @"runtimeVersion": @"", @"serviceAccount": @"", @"state": @"" },
                              @"description": @"",
                              @"etag": @"",
                              @"labels": @{  },
                              @"name": @"",
                              @"onlinePredictionConsoleLogging": @NO,
                              @"onlinePredictionLogging": @NO,
                              @"regions": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:parent/models"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1/:parent/models" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:parent/models",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'defaultVersion' => [
        'acceleratorConfig' => [
                'count' => '',
                'type' => ''
        ],
        'autoScaling' => [
                'maxNodes' => 0,
                'metrics' => [
                                [
                                                                'name' => '',
                                                                'target' => 0
                                ]
                ],
                'minNodes' => 0
        ],
        'container' => [
                'args' => [
                                
                ],
                'command' => [
                                
                ],
                'env' => [
                                [
                                                                'name' => '',
                                                                'value' => ''
                                ]
                ],
                'image' => '',
                'ports' => [
                                [
                                                                'containerPort' => 0
                                ]
                ]
        ],
        'createTime' => '',
        'deploymentUri' => '',
        'description' => '',
        'errorMessage' => '',
        'etag' => '',
        'explanationConfig' => [
                'integratedGradientsAttribution' => [
                                'numIntegralSteps' => 0
                ],
                'sampledShapleyAttribution' => [
                                'numPaths' => 0
                ],
                'xraiAttribution' => [
                                'numIntegralSteps' => 0
                ]
        ],
        'framework' => '',
        'isDefault' => null,
        'labels' => [
                
        ],
        'lastMigrationModelId' => '',
        'lastMigrationTime' => '',
        'lastUseTime' => '',
        'machineType' => '',
        'manualScaling' => [
                'nodes' => 0
        ],
        'name' => '',
        'packageUris' => [
                
        ],
        'predictionClass' => '',
        'pythonVersion' => '',
        'requestLoggingConfig' => [
                'bigqueryTableName' => '',
                'samplingPercentage' => ''
        ],
        'routes' => [
                'health' => '',
                'predict' => ''
        ],
        'runtimeVersion' => '',
        'serviceAccount' => '',
        'state' => ''
    ],
    'description' => '',
    'etag' => '',
    'labels' => [
        
    ],
    'name' => '',
    'onlinePredictionConsoleLogging' => null,
    'onlinePredictionLogging' => null,
    'regions' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:parent/models', [
  'body' => '{
  "defaultVersion": {
    "acceleratorConfig": {
      "count": "",
      "type": ""
    },
    "autoScaling": {
      "maxNodes": 0,
      "metrics": [
        {
          "name": "",
          "target": 0
        }
      ],
      "minNodes": 0
    },
    "container": {
      "args": [],
      "command": [],
      "env": [
        {
          "name": "",
          "value": ""
        }
      ],
      "image": "",
      "ports": [
        {
          "containerPort": 0
        }
      ]
    },
    "createTime": "",
    "deploymentUri": "",
    "description": "",
    "errorMessage": "",
    "etag": "",
    "explanationConfig": {
      "integratedGradientsAttribution": {
        "numIntegralSteps": 0
      },
      "sampledShapleyAttribution": {
        "numPaths": 0
      },
      "xraiAttribution": {
        "numIntegralSteps": 0
      }
    },
    "framework": "",
    "isDefault": false,
    "labels": {},
    "lastMigrationModelId": "",
    "lastMigrationTime": "",
    "lastUseTime": "",
    "machineType": "",
    "manualScaling": {
      "nodes": 0
    },
    "name": "",
    "packageUris": [],
    "predictionClass": "",
    "pythonVersion": "",
    "requestLoggingConfig": {
      "bigqueryTableName": "",
      "samplingPercentage": ""
    },
    "routes": {
      "health": "",
      "predict": ""
    },
    "runtimeVersion": "",
    "serviceAccount": "",
    "state": ""
  },
  "description": "",
  "etag": "",
  "labels": {},
  "name": "",
  "onlinePredictionConsoleLogging": false,
  "onlinePredictionLogging": false,
  "regions": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:parent/models');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'defaultVersion' => [
    'acceleratorConfig' => [
        'count' => '',
        'type' => ''
    ],
    'autoScaling' => [
        'maxNodes' => 0,
        'metrics' => [
                [
                                'name' => '',
                                'target' => 0
                ]
        ],
        'minNodes' => 0
    ],
    'container' => [
        'args' => [
                
        ],
        'command' => [
                
        ],
        'env' => [
                [
                                'name' => '',
                                'value' => ''
                ]
        ],
        'image' => '',
        'ports' => [
                [
                                'containerPort' => 0
                ]
        ]
    ],
    'createTime' => '',
    'deploymentUri' => '',
    'description' => '',
    'errorMessage' => '',
    'etag' => '',
    'explanationConfig' => [
        'integratedGradientsAttribution' => [
                'numIntegralSteps' => 0
        ],
        'sampledShapleyAttribution' => [
                'numPaths' => 0
        ],
        'xraiAttribution' => [
                'numIntegralSteps' => 0
        ]
    ],
    'framework' => '',
    'isDefault' => null,
    'labels' => [
        
    ],
    'lastMigrationModelId' => '',
    'lastMigrationTime' => '',
    'lastUseTime' => '',
    'machineType' => '',
    'manualScaling' => [
        'nodes' => 0
    ],
    'name' => '',
    'packageUris' => [
        
    ],
    'predictionClass' => '',
    'pythonVersion' => '',
    'requestLoggingConfig' => [
        'bigqueryTableName' => '',
        'samplingPercentage' => ''
    ],
    'routes' => [
        'health' => '',
        'predict' => ''
    ],
    'runtimeVersion' => '',
    'serviceAccount' => '',
    'state' => ''
  ],
  'description' => '',
  'etag' => '',
  'labels' => [
    
  ],
  'name' => '',
  'onlinePredictionConsoleLogging' => null,
  'onlinePredictionLogging' => null,
  'regions' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'defaultVersion' => [
    'acceleratorConfig' => [
        'count' => '',
        'type' => ''
    ],
    'autoScaling' => [
        'maxNodes' => 0,
        'metrics' => [
                [
                                'name' => '',
                                'target' => 0
                ]
        ],
        'minNodes' => 0
    ],
    'container' => [
        'args' => [
                
        ],
        'command' => [
                
        ],
        'env' => [
                [
                                'name' => '',
                                'value' => ''
                ]
        ],
        'image' => '',
        'ports' => [
                [
                                'containerPort' => 0
                ]
        ]
    ],
    'createTime' => '',
    'deploymentUri' => '',
    'description' => '',
    'errorMessage' => '',
    'etag' => '',
    'explanationConfig' => [
        'integratedGradientsAttribution' => [
                'numIntegralSteps' => 0
        ],
        'sampledShapleyAttribution' => [
                'numPaths' => 0
        ],
        'xraiAttribution' => [
                'numIntegralSteps' => 0
        ]
    ],
    'framework' => '',
    'isDefault' => null,
    'labels' => [
        
    ],
    'lastMigrationModelId' => '',
    'lastMigrationTime' => '',
    'lastUseTime' => '',
    'machineType' => '',
    'manualScaling' => [
        'nodes' => 0
    ],
    'name' => '',
    'packageUris' => [
        
    ],
    'predictionClass' => '',
    'pythonVersion' => '',
    'requestLoggingConfig' => [
        'bigqueryTableName' => '',
        'samplingPercentage' => ''
    ],
    'routes' => [
        'health' => '',
        'predict' => ''
    ],
    'runtimeVersion' => '',
    'serviceAccount' => '',
    'state' => ''
  ],
  'description' => '',
  'etag' => '',
  'labels' => [
    
  ],
  'name' => '',
  'onlinePredictionConsoleLogging' => null,
  'onlinePredictionLogging' => null,
  'regions' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v1/:parent/models');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:parent/models' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "defaultVersion": {
    "acceleratorConfig": {
      "count": "",
      "type": ""
    },
    "autoScaling": {
      "maxNodes": 0,
      "metrics": [
        {
          "name": "",
          "target": 0
        }
      ],
      "minNodes": 0
    },
    "container": {
      "args": [],
      "command": [],
      "env": [
        {
          "name": "",
          "value": ""
        }
      ],
      "image": "",
      "ports": [
        {
          "containerPort": 0
        }
      ]
    },
    "createTime": "",
    "deploymentUri": "",
    "description": "",
    "errorMessage": "",
    "etag": "",
    "explanationConfig": {
      "integratedGradientsAttribution": {
        "numIntegralSteps": 0
      },
      "sampledShapleyAttribution": {
        "numPaths": 0
      },
      "xraiAttribution": {
        "numIntegralSteps": 0
      }
    },
    "framework": "",
    "isDefault": false,
    "labels": {},
    "lastMigrationModelId": "",
    "lastMigrationTime": "",
    "lastUseTime": "",
    "machineType": "",
    "manualScaling": {
      "nodes": 0
    },
    "name": "",
    "packageUris": [],
    "predictionClass": "",
    "pythonVersion": "",
    "requestLoggingConfig": {
      "bigqueryTableName": "",
      "samplingPercentage": ""
    },
    "routes": {
      "health": "",
      "predict": ""
    },
    "runtimeVersion": "",
    "serviceAccount": "",
    "state": ""
  },
  "description": "",
  "etag": "",
  "labels": {},
  "name": "",
  "onlinePredictionConsoleLogging": false,
  "onlinePredictionLogging": false,
  "regions": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:parent/models' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "defaultVersion": {
    "acceleratorConfig": {
      "count": "",
      "type": ""
    },
    "autoScaling": {
      "maxNodes": 0,
      "metrics": [
        {
          "name": "",
          "target": 0
        }
      ],
      "minNodes": 0
    },
    "container": {
      "args": [],
      "command": [],
      "env": [
        {
          "name": "",
          "value": ""
        }
      ],
      "image": "",
      "ports": [
        {
          "containerPort": 0
        }
      ]
    },
    "createTime": "",
    "deploymentUri": "",
    "description": "",
    "errorMessage": "",
    "etag": "",
    "explanationConfig": {
      "integratedGradientsAttribution": {
        "numIntegralSteps": 0
      },
      "sampledShapleyAttribution": {
        "numPaths": 0
      },
      "xraiAttribution": {
        "numIntegralSteps": 0
      }
    },
    "framework": "",
    "isDefault": false,
    "labels": {},
    "lastMigrationModelId": "",
    "lastMigrationTime": "",
    "lastUseTime": "",
    "machineType": "",
    "manualScaling": {
      "nodes": 0
    },
    "name": "",
    "packageUris": [],
    "predictionClass": "",
    "pythonVersion": "",
    "requestLoggingConfig": {
      "bigqueryTableName": "",
      "samplingPercentage": ""
    },
    "routes": {
      "health": "",
      "predict": ""
    },
    "runtimeVersion": "",
    "serviceAccount": "",
    "state": ""
  },
  "description": "",
  "etag": "",
  "labels": {},
  "name": "",
  "onlinePredictionConsoleLogging": false,
  "onlinePredictionLogging": false,
  "regions": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1/:parent/models", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:parent/models"

payload = {
    "defaultVersion": {
        "acceleratorConfig": {
            "count": "",
            "type": ""
        },
        "autoScaling": {
            "maxNodes": 0,
            "metrics": [
                {
                    "name": "",
                    "target": 0
                }
            ],
            "minNodes": 0
        },
        "container": {
            "args": [],
            "command": [],
            "env": [
                {
                    "name": "",
                    "value": ""
                }
            ],
            "image": "",
            "ports": [{ "containerPort": 0 }]
        },
        "createTime": "",
        "deploymentUri": "",
        "description": "",
        "errorMessage": "",
        "etag": "",
        "explanationConfig": {
            "integratedGradientsAttribution": { "numIntegralSteps": 0 },
            "sampledShapleyAttribution": { "numPaths": 0 },
            "xraiAttribution": { "numIntegralSteps": 0 }
        },
        "framework": "",
        "isDefault": False,
        "labels": {},
        "lastMigrationModelId": "",
        "lastMigrationTime": "",
        "lastUseTime": "",
        "machineType": "",
        "manualScaling": { "nodes": 0 },
        "name": "",
        "packageUris": [],
        "predictionClass": "",
        "pythonVersion": "",
        "requestLoggingConfig": {
            "bigqueryTableName": "",
            "samplingPercentage": ""
        },
        "routes": {
            "health": "",
            "predict": ""
        },
        "runtimeVersion": "",
        "serviceAccount": "",
        "state": ""
    },
    "description": "",
    "etag": "",
    "labels": {},
    "name": "",
    "onlinePredictionConsoleLogging": False,
    "onlinePredictionLogging": False,
    "regions": []
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:parent/models"

payload <- "{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/:parent/models")

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  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v1/:parent/models') do |req|
  req.body = "{\n  \"defaultVersion\": {\n    \"acceleratorConfig\": {\n      \"count\": \"\",\n      \"type\": \"\"\n    },\n    \"autoScaling\": {\n      \"maxNodes\": 0,\n      \"metrics\": [\n        {\n          \"name\": \"\",\n          \"target\": 0\n        }\n      ],\n      \"minNodes\": 0\n    },\n    \"container\": {\n      \"args\": [],\n      \"command\": [],\n      \"env\": [\n        {\n          \"name\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"image\": \"\",\n      \"ports\": [\n        {\n          \"containerPort\": 0\n        }\n      ]\n    },\n    \"createTime\": \"\",\n    \"deploymentUri\": \"\",\n    \"description\": \"\",\n    \"errorMessage\": \"\",\n    \"etag\": \"\",\n    \"explanationConfig\": {\n      \"integratedGradientsAttribution\": {\n        \"numIntegralSteps\": 0\n      },\n      \"sampledShapleyAttribution\": {\n        \"numPaths\": 0\n      },\n      \"xraiAttribution\": {\n        \"numIntegralSteps\": 0\n      }\n    },\n    \"framework\": \"\",\n    \"isDefault\": false,\n    \"labels\": {},\n    \"lastMigrationModelId\": \"\",\n    \"lastMigrationTime\": \"\",\n    \"lastUseTime\": \"\",\n    \"machineType\": \"\",\n    \"manualScaling\": {\n      \"nodes\": 0\n    },\n    \"name\": \"\",\n    \"packageUris\": [],\n    \"predictionClass\": \"\",\n    \"pythonVersion\": \"\",\n    \"requestLoggingConfig\": {\n      \"bigqueryTableName\": \"\",\n      \"samplingPercentage\": \"\"\n    },\n    \"routes\": {\n      \"health\": \"\",\n      \"predict\": \"\"\n    },\n    \"runtimeVersion\": \"\",\n    \"serviceAccount\": \"\",\n    \"state\": \"\"\n  },\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"onlinePredictionConsoleLogging\": false,\n  \"onlinePredictionLogging\": false,\n  \"regions\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:parent/models";

    let payload = json!({
        "defaultVersion": json!({
            "acceleratorConfig": json!({
                "count": "",
                "type": ""
            }),
            "autoScaling": json!({
                "maxNodes": 0,
                "metrics": (
                    json!({
                        "name": "",
                        "target": 0
                    })
                ),
                "minNodes": 0
            }),
            "container": json!({
                "args": (),
                "command": (),
                "env": (
                    json!({
                        "name": "",
                        "value": ""
                    })
                ),
                "image": "",
                "ports": (json!({"containerPort": 0}))
            }),
            "createTime": "",
            "deploymentUri": "",
            "description": "",
            "errorMessage": "",
            "etag": "",
            "explanationConfig": json!({
                "integratedGradientsAttribution": json!({"numIntegralSteps": 0}),
                "sampledShapleyAttribution": json!({"numPaths": 0}),
                "xraiAttribution": json!({"numIntegralSteps": 0})
            }),
            "framework": "",
            "isDefault": false,
            "labels": json!({}),
            "lastMigrationModelId": "",
            "lastMigrationTime": "",
            "lastUseTime": "",
            "machineType": "",
            "manualScaling": json!({"nodes": 0}),
            "name": "",
            "packageUris": (),
            "predictionClass": "",
            "pythonVersion": "",
            "requestLoggingConfig": json!({
                "bigqueryTableName": "",
                "samplingPercentage": ""
            }),
            "routes": json!({
                "health": "",
                "predict": ""
            }),
            "runtimeVersion": "",
            "serviceAccount": "",
            "state": ""
        }),
        "description": "",
        "etag": "",
        "labels": json!({}),
        "name": "",
        "onlinePredictionConsoleLogging": false,
        "onlinePredictionLogging": false,
        "regions": ()
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:parent/models \
  --header 'content-type: application/json' \
  --data '{
  "defaultVersion": {
    "acceleratorConfig": {
      "count": "",
      "type": ""
    },
    "autoScaling": {
      "maxNodes": 0,
      "metrics": [
        {
          "name": "",
          "target": 0
        }
      ],
      "minNodes": 0
    },
    "container": {
      "args": [],
      "command": [],
      "env": [
        {
          "name": "",
          "value": ""
        }
      ],
      "image": "",
      "ports": [
        {
          "containerPort": 0
        }
      ]
    },
    "createTime": "",
    "deploymentUri": "",
    "description": "",
    "errorMessage": "",
    "etag": "",
    "explanationConfig": {
      "integratedGradientsAttribution": {
        "numIntegralSteps": 0
      },
      "sampledShapleyAttribution": {
        "numPaths": 0
      },
      "xraiAttribution": {
        "numIntegralSteps": 0
      }
    },
    "framework": "",
    "isDefault": false,
    "labels": {},
    "lastMigrationModelId": "",
    "lastMigrationTime": "",
    "lastUseTime": "",
    "machineType": "",
    "manualScaling": {
      "nodes": 0
    },
    "name": "",
    "packageUris": [],
    "predictionClass": "",
    "pythonVersion": "",
    "requestLoggingConfig": {
      "bigqueryTableName": "",
      "samplingPercentage": ""
    },
    "routes": {
      "health": "",
      "predict": ""
    },
    "runtimeVersion": "",
    "serviceAccount": "",
    "state": ""
  },
  "description": "",
  "etag": "",
  "labels": {},
  "name": "",
  "onlinePredictionConsoleLogging": false,
  "onlinePredictionLogging": false,
  "regions": []
}'
echo '{
  "defaultVersion": {
    "acceleratorConfig": {
      "count": "",
      "type": ""
    },
    "autoScaling": {
      "maxNodes": 0,
      "metrics": [
        {
          "name": "",
          "target": 0
        }
      ],
      "minNodes": 0
    },
    "container": {
      "args": [],
      "command": [],
      "env": [
        {
          "name": "",
          "value": ""
        }
      ],
      "image": "",
      "ports": [
        {
          "containerPort": 0
        }
      ]
    },
    "createTime": "",
    "deploymentUri": "",
    "description": "",
    "errorMessage": "",
    "etag": "",
    "explanationConfig": {
      "integratedGradientsAttribution": {
        "numIntegralSteps": 0
      },
      "sampledShapleyAttribution": {
        "numPaths": 0
      },
      "xraiAttribution": {
        "numIntegralSteps": 0
      }
    },
    "framework": "",
    "isDefault": false,
    "labels": {},
    "lastMigrationModelId": "",
    "lastMigrationTime": "",
    "lastUseTime": "",
    "machineType": "",
    "manualScaling": {
      "nodes": 0
    },
    "name": "",
    "packageUris": [],
    "predictionClass": "",
    "pythonVersion": "",
    "requestLoggingConfig": {
      "bigqueryTableName": "",
      "samplingPercentage": ""
    },
    "routes": {
      "health": "",
      "predict": ""
    },
    "runtimeVersion": "",
    "serviceAccount": "",
    "state": ""
  },
  "description": "",
  "etag": "",
  "labels": {},
  "name": "",
  "onlinePredictionConsoleLogging": false,
  "onlinePredictionLogging": false,
  "regions": []
}' |  \
  http POST {{baseUrl}}/v1/:parent/models \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "defaultVersion": {\n    "acceleratorConfig": {\n      "count": "",\n      "type": ""\n    },\n    "autoScaling": {\n      "maxNodes": 0,\n      "metrics": [\n        {\n          "name": "",\n          "target": 0\n        }\n      ],\n      "minNodes": 0\n    },\n    "container": {\n      "args": [],\n      "command": [],\n      "env": [\n        {\n          "name": "",\n          "value": ""\n        }\n      ],\n      "image": "",\n      "ports": [\n        {\n          "containerPort": 0\n        }\n      ]\n    },\n    "createTime": "",\n    "deploymentUri": "",\n    "description": "",\n    "errorMessage": "",\n    "etag": "",\n    "explanationConfig": {\n      "integratedGradientsAttribution": {\n        "numIntegralSteps": 0\n      },\n      "sampledShapleyAttribution": {\n        "numPaths": 0\n      },\n      "xraiAttribution": {\n        "numIntegralSteps": 0\n      }\n    },\n    "framework": "",\n    "isDefault": false,\n    "labels": {},\n    "lastMigrationModelId": "",\n    "lastMigrationTime": "",\n    "lastUseTime": "",\n    "machineType": "",\n    "manualScaling": {\n      "nodes": 0\n    },\n    "name": "",\n    "packageUris": [],\n    "predictionClass": "",\n    "pythonVersion": "",\n    "requestLoggingConfig": {\n      "bigqueryTableName": "",\n      "samplingPercentage": ""\n    },\n    "routes": {\n      "health": "",\n      "predict": ""\n    },\n    "runtimeVersion": "",\n    "serviceAccount": "",\n    "state": ""\n  },\n  "description": "",\n  "etag": "",\n  "labels": {},\n  "name": "",\n  "onlinePredictionConsoleLogging": false,\n  "onlinePredictionLogging": false,\n  "regions": []\n}' \
  --output-document \
  - {{baseUrl}}/v1/:parent/models
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "defaultVersion": [
    "acceleratorConfig": [
      "count": "",
      "type": ""
    ],
    "autoScaling": [
      "maxNodes": 0,
      "metrics": [
        [
          "name": "",
          "target": 0
        ]
      ],
      "minNodes": 0
    ],
    "container": [
      "args": [],
      "command": [],
      "env": [
        [
          "name": "",
          "value": ""
        ]
      ],
      "image": "",
      "ports": [["containerPort": 0]]
    ],
    "createTime": "",
    "deploymentUri": "",
    "description": "",
    "errorMessage": "",
    "etag": "",
    "explanationConfig": [
      "integratedGradientsAttribution": ["numIntegralSteps": 0],
      "sampledShapleyAttribution": ["numPaths": 0],
      "xraiAttribution": ["numIntegralSteps": 0]
    ],
    "framework": "",
    "isDefault": false,
    "labels": [],
    "lastMigrationModelId": "",
    "lastMigrationTime": "",
    "lastUseTime": "",
    "machineType": "",
    "manualScaling": ["nodes": 0],
    "name": "",
    "packageUris": [],
    "predictionClass": "",
    "pythonVersion": "",
    "requestLoggingConfig": [
      "bigqueryTableName": "",
      "samplingPercentage": ""
    ],
    "routes": [
      "health": "",
      "predict": ""
    ],
    "runtimeVersion": "",
    "serviceAccount": "",
    "state": ""
  ],
  "description": "",
  "etag": "",
  "labels": [],
  "name": "",
  "onlinePredictionConsoleLogging": false,
  "onlinePredictionLogging": false,
  "regions": []
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:parent/models")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET ml.projects.models.getIamPolicy
{{baseUrl}}/v1/:resource:getIamPolicy
QUERY PARAMS

resource
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:resource:getIamPolicy");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1/:resource:getIamPolicy")
require "http/client"

url = "{{baseUrl}}/v1/:resource:getIamPolicy"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/v1/:resource:getIamPolicy"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:resource:getIamPolicy");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:resource:getIamPolicy"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/v1/:resource:getIamPolicy HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1/:resource:getIamPolicy")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:resource:getIamPolicy"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:resource:getIamPolicy")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1/:resource:getIamPolicy")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v1/:resource:getIamPolicy');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/v1/:resource:getIamPolicy'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:resource:getIamPolicy';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:resource:getIamPolicy',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1/:resource:getIamPolicy")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:resource:getIamPolicy',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/v1/:resource:getIamPolicy'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1/:resource:getIamPolicy');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/v1/:resource:getIamPolicy'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:resource:getIamPolicy';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:resource:getIamPolicy"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1/:resource:getIamPolicy" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:resource:getIamPolicy",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v1/:resource:getIamPolicy');

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:resource:getIamPolicy');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1/:resource:getIamPolicy');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:resource:getIamPolicy' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:resource:getIamPolicy' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1/:resource:getIamPolicy")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:resource:getIamPolicy"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:resource:getIamPolicy"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/:resource:getIamPolicy")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/v1/:resource:getIamPolicy') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:resource:getIamPolicy";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v1/:resource:getIamPolicy
http GET {{baseUrl}}/v1/:resource:getIamPolicy
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1/:resource:getIamPolicy
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:resource:getIamPolicy")! 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 ml.projects.models.list
{{baseUrl}}/v1/:parent/models
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:parent/models");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1/:parent/models")
require "http/client"

url = "{{baseUrl}}/v1/:parent/models"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/v1/:parent/models"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:parent/models");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:parent/models"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/v1/:parent/models HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1/:parent/models")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:parent/models"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:parent/models")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1/:parent/models")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v1/:parent/models');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/models'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:parent/models';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:parent/models',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1/:parent/models")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:parent/models',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/models'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1/:parent/models');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/models'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:parent/models';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:parent/models"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1/:parent/models" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:parent/models",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v1/:parent/models');

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:parent/models');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1/:parent/models');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:parent/models' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:parent/models' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1/:parent/models")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:parent/models"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:parent/models"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/:parent/models")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/v1/:parent/models') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:parent/models";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v1/:parent/models
http GET {{baseUrl}}/v1/:parent/models
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1/:parent/models
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:parent/models")! 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 ml.projects.models.setIamPolicy
{{baseUrl}}/v1/:resource:setIamPolicy
QUERY PARAMS

resource
BODY json

{
  "policy": {
    "auditConfigs": [
      {
        "auditLogConfigs": [
          {
            "exemptedMembers": [],
            "logType": ""
          }
        ],
        "service": ""
      }
    ],
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  },
  "updateMask": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:resource:setIamPolicy");

struct curl_slist *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  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1/:resource:setIamPolicy" {:content-type :json
                                                                      :form-params {:policy {:auditConfigs [{:auditLogConfigs [{:exemptedMembers []
                                                                                                                                :logType ""}]
                                                                                                             :service ""}]
                                                                                             :bindings [{:condition {:description ""
                                                                                                                     :expression ""
                                                                                                                     :location ""
                                                                                                                     :title ""}
                                                                                                         :members []
                                                                                                         :role ""}]
                                                                                             :etag ""
                                                                                             :version 0}
                                                                                    :updateMask ""}})
require "http/client"

url = "{{baseUrl}}/v1/:resource:setIamPolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:resource:setIamPolicy"),
    Content = new StringContent("{\n  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\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}}/v1/:resource:setIamPolicy");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:resource:setIamPolicy"

	payload := strings.NewReader("{\n  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v1/:resource:setIamPolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 488

{
  "policy": {
    "auditConfigs": [
      {
        "auditLogConfigs": [
          {
            "exemptedMembers": [],
            "logType": ""
          }
        ],
        "service": ""
      }
    ],
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  },
  "updateMask": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:resource:setIamPolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:resource:setIamPolicy"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\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  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:resource:setIamPolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:resource:setIamPolicy")
  .header("content-type", "application/json")
  .body("{\n  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  policy: {
    auditConfigs: [
      {
        auditLogConfigs: [
          {
            exemptedMembers: [],
            logType: ''
          }
        ],
        service: ''
      }
    ],
    bindings: [
      {
        condition: {
          description: '',
          expression: '',
          location: '',
          title: ''
        },
        members: [],
        role: ''
      }
    ],
    etag: '',
    version: 0
  },
  updateMask: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1/:resource:setIamPolicy');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:resource:setIamPolicy',
  headers: {'content-type': 'application/json'},
  data: {
    policy: {
      auditConfigs: [{auditLogConfigs: [{exemptedMembers: [], logType: ''}], service: ''}],
      bindings: [
        {
          condition: {description: '', expression: '', location: '', title: ''},
          members: [],
          role: ''
        }
      ],
      etag: '',
      version: 0
    },
    updateMask: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:resource:setIamPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"policy":{"auditConfigs":[{"auditLogConfigs":[{"exemptedMembers":[],"logType":""}],"service":""}],"bindings":[{"condition":{"description":"","expression":"","location":"","title":""},"members":[],"role":""}],"etag":"","version":0},"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}}/v1/:resource:setIamPolicy',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "policy": {\n    "auditConfigs": [\n      {\n        "auditLogConfigs": [\n          {\n            "exemptedMembers": [],\n            "logType": ""\n          }\n        ],\n        "service": ""\n      }\n    ],\n    "bindings": [\n      {\n        "condition": {\n          "description": "",\n          "expression": "",\n          "location": "",\n          "title": ""\n        },\n        "members": [],\n        "role": ""\n      }\n    ],\n    "etag": "",\n    "version": 0\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  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:resource:setIamPolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:resource:setIamPolicy',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  policy: {
    auditConfigs: [{auditLogConfigs: [{exemptedMembers: [], logType: ''}], service: ''}],
    bindings: [
      {
        condition: {description: '', expression: '', location: '', title: ''},
        members: [],
        role: ''
      }
    ],
    etag: '',
    version: 0
  },
  updateMask: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:resource:setIamPolicy',
  headers: {'content-type': 'application/json'},
  body: {
    policy: {
      auditConfigs: [{auditLogConfigs: [{exemptedMembers: [], logType: ''}], service: ''}],
      bindings: [
        {
          condition: {description: '', expression: '', location: '', title: ''},
          members: [],
          role: ''
        }
      ],
      etag: '',
      version: 0
    },
    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('POST', '{{baseUrl}}/v1/:resource:setIamPolicy');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  policy: {
    auditConfigs: [
      {
        auditLogConfigs: [
          {
            exemptedMembers: [],
            logType: ''
          }
        ],
        service: ''
      }
    ],
    bindings: [
      {
        condition: {
          description: '',
          expression: '',
          location: '',
          title: ''
        },
        members: [],
        role: ''
      }
    ],
    etag: '',
    version: 0
  },
  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: 'POST',
  url: '{{baseUrl}}/v1/:resource:setIamPolicy',
  headers: {'content-type': 'application/json'},
  data: {
    policy: {
      auditConfigs: [{auditLogConfigs: [{exemptedMembers: [], logType: ''}], service: ''}],
      bindings: [
        {
          condition: {description: '', expression: '', location: '', title: ''},
          members: [],
          role: ''
        }
      ],
      etag: '',
      version: 0
    },
    updateMask: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:resource:setIamPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"policy":{"auditConfigs":[{"auditLogConfigs":[{"exemptedMembers":[],"logType":""}],"service":""}],"bindings":[{"condition":{"description":"","expression":"","location":"","title":""},"members":[],"role":""}],"etag":"","version":0},"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 = @{ @"policy": @{ @"auditConfigs": @[ @{ @"auditLogConfigs": @[ @{ @"exemptedMembers": @[  ], @"logType": @"" } ], @"service": @"" } ], @"bindings": @[ @{ @"condition": @{ @"description": @"", @"expression": @"", @"location": @"", @"title": @"" }, @"members": @[  ], @"role": @"" } ], @"etag": @"", @"version": @0 },
                              @"updateMask": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:resource:setIamPolicy"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1/:resource:setIamPolicy" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:resource:setIamPolicy",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'policy' => [
        'auditConfigs' => [
                [
                                'auditLogConfigs' => [
                                                                [
                                                                                                                                'exemptedMembers' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'logType' => ''
                                                                ]
                                ],
                                'service' => ''
                ]
        ],
        'bindings' => [
                [
                                'condition' => [
                                                                'description' => '',
                                                                'expression' => '',
                                                                'location' => '',
                                                                'title' => ''
                                ],
                                'members' => [
                                                                
                                ],
                                'role' => ''
                ]
        ],
        'etag' => '',
        'version' => 0
    ],
    '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('POST', '{{baseUrl}}/v1/:resource:setIamPolicy', [
  'body' => '{
  "policy": {
    "auditConfigs": [
      {
        "auditLogConfigs": [
          {
            "exemptedMembers": [],
            "logType": ""
          }
        ],
        "service": ""
      }
    ],
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  },
  "updateMask": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:resource:setIamPolicy');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'policy' => [
    'auditConfigs' => [
        [
                'auditLogConfigs' => [
                                [
                                                                'exemptedMembers' => [
                                                                                                                                
                                                                ],
                                                                'logType' => ''
                                ]
                ],
                'service' => ''
        ]
    ],
    'bindings' => [
        [
                'condition' => [
                                'description' => '',
                                'expression' => '',
                                'location' => '',
                                'title' => ''
                ],
                'members' => [
                                
                ],
                'role' => ''
        ]
    ],
    'etag' => '',
    'version' => 0
  ],
  'updateMask' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'policy' => [
    'auditConfigs' => [
        [
                'auditLogConfigs' => [
                                [
                                                                'exemptedMembers' => [
                                                                                                                                
                                                                ],
                                                                'logType' => ''
                                ]
                ],
                'service' => ''
        ]
    ],
    'bindings' => [
        [
                'condition' => [
                                'description' => '',
                                'expression' => '',
                                'location' => '',
                                'title' => ''
                ],
                'members' => [
                                
                ],
                'role' => ''
        ]
    ],
    'etag' => '',
    'version' => 0
  ],
  'updateMask' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1/:resource:setIamPolicy');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:resource:setIamPolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "policy": {
    "auditConfigs": [
      {
        "auditLogConfigs": [
          {
            "exemptedMembers": [],
            "logType": ""
          }
        ],
        "service": ""
      }
    ],
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  },
  "updateMask": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:resource:setIamPolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "policy": {
    "auditConfigs": [
      {
        "auditLogConfigs": [
          {
            "exemptedMembers": [],
            "logType": ""
          }
        ],
        "service": ""
      }
    ],
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  },
  "updateMask": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1/:resource:setIamPolicy", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:resource:setIamPolicy"

payload = {
    "policy": {
        "auditConfigs": [
            {
                "auditLogConfigs": [
                    {
                        "exemptedMembers": [],
                        "logType": ""
                    }
                ],
                "service": ""
            }
        ],
        "bindings": [
            {
                "condition": {
                    "description": "",
                    "expression": "",
                    "location": "",
                    "title": ""
                },
                "members": [],
                "role": ""
            }
        ],
        "etag": "",
        "version": 0
    },
    "updateMask": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:resource:setIamPolicy"

payload <- "{\n  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/:resource:setIamPolicy")

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  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\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.post('/baseUrl/v1/:resource:setIamPolicy') do |req|
  req.body = "{\n  \"policy\": {\n    \"auditConfigs\": [\n      {\n        \"auditLogConfigs\": [\n          {\n            \"exemptedMembers\": [],\n            \"logType\": \"\"\n          }\n        ],\n        \"service\": \"\"\n      }\n    ],\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  },\n  \"updateMask\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:resource:setIamPolicy";

    let payload = json!({
        "policy": json!({
            "auditConfigs": (
                json!({
                    "auditLogConfigs": (
                        json!({
                            "exemptedMembers": (),
                            "logType": ""
                        })
                    ),
                    "service": ""
                })
            ),
            "bindings": (
                json!({
                    "condition": json!({
                        "description": "",
                        "expression": "",
                        "location": "",
                        "title": ""
                    }),
                    "members": (),
                    "role": ""
                })
            ),
            "etag": "",
            "version": 0
        }),
        "updateMask": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:resource:setIamPolicy \
  --header 'content-type: application/json' \
  --data '{
  "policy": {
    "auditConfigs": [
      {
        "auditLogConfigs": [
          {
            "exemptedMembers": [],
            "logType": ""
          }
        ],
        "service": ""
      }
    ],
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  },
  "updateMask": ""
}'
echo '{
  "policy": {
    "auditConfigs": [
      {
        "auditLogConfigs": [
          {
            "exemptedMembers": [],
            "logType": ""
          }
        ],
        "service": ""
      }
    ],
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  },
  "updateMask": ""
}' |  \
  http POST {{baseUrl}}/v1/:resource:setIamPolicy \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "policy": {\n    "auditConfigs": [\n      {\n        "auditLogConfigs": [\n          {\n            "exemptedMembers": [],\n            "logType": ""\n          }\n        ],\n        "service": ""\n      }\n    ],\n    "bindings": [\n      {\n        "condition": {\n          "description": "",\n          "expression": "",\n          "location": "",\n          "title": ""\n        },\n        "members": [],\n        "role": ""\n      }\n    ],\n    "etag": "",\n    "version": 0\n  },\n  "updateMask": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1/:resource:setIamPolicy
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "policy": [
    "auditConfigs": [
      [
        "auditLogConfigs": [
          [
            "exemptedMembers": [],
            "logType": ""
          ]
        ],
        "service": ""
      ]
    ],
    "bindings": [
      [
        "condition": [
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        ],
        "members": [],
        "role": ""
      ]
    ],
    "etag": "",
    "version": 0
  ],
  "updateMask": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:resource:setIamPolicy")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ml.projects.models.testIamPermissions
{{baseUrl}}/v1/:resource:testIamPermissions
QUERY PARAMS

resource
BODY json

{
  "permissions": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:resource:testIamPermissions");

struct curl_slist *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  \"permissions\": []\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1/:resource:testIamPermissions" {:content-type :json
                                                                            :form-params {:permissions []}})
require "http/client"

url = "{{baseUrl}}/v1/:resource:testIamPermissions"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"permissions\": []\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:resource:testIamPermissions"),
    Content = new StringContent("{\n  \"permissions\": []\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:resource:testIamPermissions");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"permissions\": []\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:resource:testIamPermissions"

	payload := strings.NewReader("{\n  \"permissions\": []\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v1/:resource:testIamPermissions HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 23

{
  "permissions": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:resource:testIamPermissions")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"permissions\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:resource:testIamPermissions"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"permissions\": []\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"permissions\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:resource:testIamPermissions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:resource:testIamPermissions")
  .header("content-type", "application/json")
  .body("{\n  \"permissions\": []\n}")
  .asString();
const data = JSON.stringify({
  permissions: []
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1/:resource:testIamPermissions');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:resource:testIamPermissions',
  headers: {'content-type': 'application/json'},
  data: {permissions: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:resource:testIamPermissions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"permissions":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:resource:testIamPermissions',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "permissions": []\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"permissions\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:resource:testIamPermissions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:resource:testIamPermissions',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({permissions: []}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:resource:testIamPermissions',
  headers: {'content-type': 'application/json'},
  body: {permissions: []},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v1/:resource:testIamPermissions');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  permissions: []
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:resource:testIamPermissions',
  headers: {'content-type': 'application/json'},
  data: {permissions: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:resource:testIamPermissions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"permissions":[]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"permissions": @[  ] };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:resource:testIamPermissions"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1/:resource:testIamPermissions" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"permissions\": []\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:resource:testIamPermissions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'permissions' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:resource:testIamPermissions', [
  'body' => '{
  "permissions": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:resource:testIamPermissions');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'permissions' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'permissions' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v1/:resource:testIamPermissions');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:resource:testIamPermissions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "permissions": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:resource:testIamPermissions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "permissions": []
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"permissions\": []\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1/:resource:testIamPermissions", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:resource:testIamPermissions"

payload = { "permissions": [] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:resource:testIamPermissions"

payload <- "{\n  \"permissions\": []\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/:resource:testIamPermissions")

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  \"permissions\": []\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v1/:resource:testIamPermissions') do |req|
  req.body = "{\n  \"permissions\": []\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:resource:testIamPermissions";

    let payload = json!({"permissions": ()});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:resource:testIamPermissions \
  --header 'content-type: application/json' \
  --data '{
  "permissions": []
}'
echo '{
  "permissions": []
}' |  \
  http POST {{baseUrl}}/v1/:resource:testIamPermissions \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "permissions": []\n}' \
  --output-document \
  - {{baseUrl}}/v1/:resource:testIamPermissions
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["permissions": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:resource:testIamPermissions")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ml.projects.models.versions.create
{{baseUrl}}/v1/:parent/versions
QUERY PARAMS

parent
BODY json

{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:parent/versions");

struct curl_slist *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  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1/:parent/versions" {:content-type :json
                                                                :form-params {:acceleratorConfig {:count ""
                                                                                                  :type ""}
                                                                              :autoScaling {:maxNodes 0
                                                                                            :metrics [{:name ""
                                                                                                       :target 0}]
                                                                                            :minNodes 0}
                                                                              :container {:args []
                                                                                          :command []
                                                                                          :env [{:name ""
                                                                                                 :value ""}]
                                                                                          :image ""
                                                                                          :ports [{:containerPort 0}]}
                                                                              :createTime ""
                                                                              :deploymentUri ""
                                                                              :description ""
                                                                              :errorMessage ""
                                                                              :etag ""
                                                                              :explanationConfig {:integratedGradientsAttribution {:numIntegralSteps 0}
                                                                                                  :sampledShapleyAttribution {:numPaths 0}
                                                                                                  :xraiAttribution {:numIntegralSteps 0}}
                                                                              :framework ""
                                                                              :isDefault false
                                                                              :labels {}
                                                                              :lastMigrationModelId ""
                                                                              :lastMigrationTime ""
                                                                              :lastUseTime ""
                                                                              :machineType ""
                                                                              :manualScaling {:nodes 0}
                                                                              :name ""
                                                                              :packageUris []
                                                                              :predictionClass ""
                                                                              :pythonVersion ""
                                                                              :requestLoggingConfig {:bigqueryTableName ""
                                                                                                     :samplingPercentage ""}
                                                                              :routes {:health ""
                                                                                       :predict ""}
                                                                              :runtimeVersion ""
                                                                              :serviceAccount ""
                                                                              :state ""}})
require "http/client"

url = "{{baseUrl}}/v1/:parent/versions"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:parent/versions"),
    Content = new StringContent("{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:parent/versions");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:parent/versions"

	payload := strings.NewReader("{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v1/:parent/versions HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1234

{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:parent/versions")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:parent/versions"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:parent/versions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:parent/versions")
  .header("content-type", "application/json")
  .body("{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  acceleratorConfig: {
    count: '',
    type: ''
  },
  autoScaling: {
    maxNodes: 0,
    metrics: [
      {
        name: '',
        target: 0
      }
    ],
    minNodes: 0
  },
  container: {
    args: [],
    command: [],
    env: [
      {
        name: '',
        value: ''
      }
    ],
    image: '',
    ports: [
      {
        containerPort: 0
      }
    ]
  },
  createTime: '',
  deploymentUri: '',
  description: '',
  errorMessage: '',
  etag: '',
  explanationConfig: {
    integratedGradientsAttribution: {
      numIntegralSteps: 0
    },
    sampledShapleyAttribution: {
      numPaths: 0
    },
    xraiAttribution: {
      numIntegralSteps: 0
    }
  },
  framework: '',
  isDefault: false,
  labels: {},
  lastMigrationModelId: '',
  lastMigrationTime: '',
  lastUseTime: '',
  machineType: '',
  manualScaling: {
    nodes: 0
  },
  name: '',
  packageUris: [],
  predictionClass: '',
  pythonVersion: '',
  requestLoggingConfig: {
    bigqueryTableName: '',
    samplingPercentage: ''
  },
  routes: {
    health: '',
    predict: ''
  },
  runtimeVersion: '',
  serviceAccount: '',
  state: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1/:parent/versions');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/versions',
  headers: {'content-type': 'application/json'},
  data: {
    acceleratorConfig: {count: '', type: ''},
    autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
    container: {
      args: [],
      command: [],
      env: [{name: '', value: ''}],
      image: '',
      ports: [{containerPort: 0}]
    },
    createTime: '',
    deploymentUri: '',
    description: '',
    errorMessage: '',
    etag: '',
    explanationConfig: {
      integratedGradientsAttribution: {numIntegralSteps: 0},
      sampledShapleyAttribution: {numPaths: 0},
      xraiAttribution: {numIntegralSteps: 0}
    },
    framework: '',
    isDefault: false,
    labels: {},
    lastMigrationModelId: '',
    lastMigrationTime: '',
    lastUseTime: '',
    machineType: '',
    manualScaling: {nodes: 0},
    name: '',
    packageUris: [],
    predictionClass: '',
    pythonVersion: '',
    requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
    routes: {health: '', predict: ''},
    runtimeVersion: '',
    serviceAccount: '',
    state: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:parent/versions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"acceleratorConfig":{"count":"","type":""},"autoScaling":{"maxNodes":0,"metrics":[{"name":"","target":0}],"minNodes":0},"container":{"args":[],"command":[],"env":[{"name":"","value":""}],"image":"","ports":[{"containerPort":0}]},"createTime":"","deploymentUri":"","description":"","errorMessage":"","etag":"","explanationConfig":{"integratedGradientsAttribution":{"numIntegralSteps":0},"sampledShapleyAttribution":{"numPaths":0},"xraiAttribution":{"numIntegralSteps":0}},"framework":"","isDefault":false,"labels":{},"lastMigrationModelId":"","lastMigrationTime":"","lastUseTime":"","machineType":"","manualScaling":{"nodes":0},"name":"","packageUris":[],"predictionClass":"","pythonVersion":"","requestLoggingConfig":{"bigqueryTableName":"","samplingPercentage":""},"routes":{"health":"","predict":""},"runtimeVersion":"","serviceAccount":"","state":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:parent/versions',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "acceleratorConfig": {\n    "count": "",\n    "type": ""\n  },\n  "autoScaling": {\n    "maxNodes": 0,\n    "metrics": [\n      {\n        "name": "",\n        "target": 0\n      }\n    ],\n    "minNodes": 0\n  },\n  "container": {\n    "args": [],\n    "command": [],\n    "env": [\n      {\n        "name": "",\n        "value": ""\n      }\n    ],\n    "image": "",\n    "ports": [\n      {\n        "containerPort": 0\n      }\n    ]\n  },\n  "createTime": "",\n  "deploymentUri": "",\n  "description": "",\n  "errorMessage": "",\n  "etag": "",\n  "explanationConfig": {\n    "integratedGradientsAttribution": {\n      "numIntegralSteps": 0\n    },\n    "sampledShapleyAttribution": {\n      "numPaths": 0\n    },\n    "xraiAttribution": {\n      "numIntegralSteps": 0\n    }\n  },\n  "framework": "",\n  "isDefault": false,\n  "labels": {},\n  "lastMigrationModelId": "",\n  "lastMigrationTime": "",\n  "lastUseTime": "",\n  "machineType": "",\n  "manualScaling": {\n    "nodes": 0\n  },\n  "name": "",\n  "packageUris": [],\n  "predictionClass": "",\n  "pythonVersion": "",\n  "requestLoggingConfig": {\n    "bigqueryTableName": "",\n    "samplingPercentage": ""\n  },\n  "routes": {\n    "health": "",\n    "predict": ""\n  },\n  "runtimeVersion": "",\n  "serviceAccount": "",\n  "state": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:parent/versions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:parent/versions',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  acceleratorConfig: {count: '', type: ''},
  autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
  container: {
    args: [],
    command: [],
    env: [{name: '', value: ''}],
    image: '',
    ports: [{containerPort: 0}]
  },
  createTime: '',
  deploymentUri: '',
  description: '',
  errorMessage: '',
  etag: '',
  explanationConfig: {
    integratedGradientsAttribution: {numIntegralSteps: 0},
    sampledShapleyAttribution: {numPaths: 0},
    xraiAttribution: {numIntegralSteps: 0}
  },
  framework: '',
  isDefault: false,
  labels: {},
  lastMigrationModelId: '',
  lastMigrationTime: '',
  lastUseTime: '',
  machineType: '',
  manualScaling: {nodes: 0},
  name: '',
  packageUris: [],
  predictionClass: '',
  pythonVersion: '',
  requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
  routes: {health: '', predict: ''},
  runtimeVersion: '',
  serviceAccount: '',
  state: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/versions',
  headers: {'content-type': 'application/json'},
  body: {
    acceleratorConfig: {count: '', type: ''},
    autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
    container: {
      args: [],
      command: [],
      env: [{name: '', value: ''}],
      image: '',
      ports: [{containerPort: 0}]
    },
    createTime: '',
    deploymentUri: '',
    description: '',
    errorMessage: '',
    etag: '',
    explanationConfig: {
      integratedGradientsAttribution: {numIntegralSteps: 0},
      sampledShapleyAttribution: {numPaths: 0},
      xraiAttribution: {numIntegralSteps: 0}
    },
    framework: '',
    isDefault: false,
    labels: {},
    lastMigrationModelId: '',
    lastMigrationTime: '',
    lastUseTime: '',
    machineType: '',
    manualScaling: {nodes: 0},
    name: '',
    packageUris: [],
    predictionClass: '',
    pythonVersion: '',
    requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
    routes: {health: '', predict: ''},
    runtimeVersion: '',
    serviceAccount: '',
    state: ''
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v1/:parent/versions');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  acceleratorConfig: {
    count: '',
    type: ''
  },
  autoScaling: {
    maxNodes: 0,
    metrics: [
      {
        name: '',
        target: 0
      }
    ],
    minNodes: 0
  },
  container: {
    args: [],
    command: [],
    env: [
      {
        name: '',
        value: ''
      }
    ],
    image: '',
    ports: [
      {
        containerPort: 0
      }
    ]
  },
  createTime: '',
  deploymentUri: '',
  description: '',
  errorMessage: '',
  etag: '',
  explanationConfig: {
    integratedGradientsAttribution: {
      numIntegralSteps: 0
    },
    sampledShapleyAttribution: {
      numPaths: 0
    },
    xraiAttribution: {
      numIntegralSteps: 0
    }
  },
  framework: '',
  isDefault: false,
  labels: {},
  lastMigrationModelId: '',
  lastMigrationTime: '',
  lastUseTime: '',
  machineType: '',
  manualScaling: {
    nodes: 0
  },
  name: '',
  packageUris: [],
  predictionClass: '',
  pythonVersion: '',
  requestLoggingConfig: {
    bigqueryTableName: '',
    samplingPercentage: ''
  },
  routes: {
    health: '',
    predict: ''
  },
  runtimeVersion: '',
  serviceAccount: '',
  state: ''
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:parent/versions',
  headers: {'content-type': 'application/json'},
  data: {
    acceleratorConfig: {count: '', type: ''},
    autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
    container: {
      args: [],
      command: [],
      env: [{name: '', value: ''}],
      image: '',
      ports: [{containerPort: 0}]
    },
    createTime: '',
    deploymentUri: '',
    description: '',
    errorMessage: '',
    etag: '',
    explanationConfig: {
      integratedGradientsAttribution: {numIntegralSteps: 0},
      sampledShapleyAttribution: {numPaths: 0},
      xraiAttribution: {numIntegralSteps: 0}
    },
    framework: '',
    isDefault: false,
    labels: {},
    lastMigrationModelId: '',
    lastMigrationTime: '',
    lastUseTime: '',
    machineType: '',
    manualScaling: {nodes: 0},
    name: '',
    packageUris: [],
    predictionClass: '',
    pythonVersion: '',
    requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
    routes: {health: '', predict: ''},
    runtimeVersion: '',
    serviceAccount: '',
    state: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:parent/versions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"acceleratorConfig":{"count":"","type":""},"autoScaling":{"maxNodes":0,"metrics":[{"name":"","target":0}],"minNodes":0},"container":{"args":[],"command":[],"env":[{"name":"","value":""}],"image":"","ports":[{"containerPort":0}]},"createTime":"","deploymentUri":"","description":"","errorMessage":"","etag":"","explanationConfig":{"integratedGradientsAttribution":{"numIntegralSteps":0},"sampledShapleyAttribution":{"numPaths":0},"xraiAttribution":{"numIntegralSteps":0}},"framework":"","isDefault":false,"labels":{},"lastMigrationModelId":"","lastMigrationTime":"","lastUseTime":"","machineType":"","manualScaling":{"nodes":0},"name":"","packageUris":[],"predictionClass":"","pythonVersion":"","requestLoggingConfig":{"bigqueryTableName":"","samplingPercentage":""},"routes":{"health":"","predict":""},"runtimeVersion":"","serviceAccount":"","state":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"acceleratorConfig": @{ @"count": @"", @"type": @"" },
                              @"autoScaling": @{ @"maxNodes": @0, @"metrics": @[ @{ @"name": @"", @"target": @0 } ], @"minNodes": @0 },
                              @"container": @{ @"args": @[  ], @"command": @[  ], @"env": @[ @{ @"name": @"", @"value": @"" } ], @"image": @"", @"ports": @[ @{ @"containerPort": @0 } ] },
                              @"createTime": @"",
                              @"deploymentUri": @"",
                              @"description": @"",
                              @"errorMessage": @"",
                              @"etag": @"",
                              @"explanationConfig": @{ @"integratedGradientsAttribution": @{ @"numIntegralSteps": @0 }, @"sampledShapleyAttribution": @{ @"numPaths": @0 }, @"xraiAttribution": @{ @"numIntegralSteps": @0 } },
                              @"framework": @"",
                              @"isDefault": @NO,
                              @"labels": @{  },
                              @"lastMigrationModelId": @"",
                              @"lastMigrationTime": @"",
                              @"lastUseTime": @"",
                              @"machineType": @"",
                              @"manualScaling": @{ @"nodes": @0 },
                              @"name": @"",
                              @"packageUris": @[  ],
                              @"predictionClass": @"",
                              @"pythonVersion": @"",
                              @"requestLoggingConfig": @{ @"bigqueryTableName": @"", @"samplingPercentage": @"" },
                              @"routes": @{ @"health": @"", @"predict": @"" },
                              @"runtimeVersion": @"",
                              @"serviceAccount": @"",
                              @"state": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:parent/versions"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1/:parent/versions" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:parent/versions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'acceleratorConfig' => [
        'count' => '',
        'type' => ''
    ],
    'autoScaling' => [
        'maxNodes' => 0,
        'metrics' => [
                [
                                'name' => '',
                                'target' => 0
                ]
        ],
        'minNodes' => 0
    ],
    'container' => [
        'args' => [
                
        ],
        'command' => [
                
        ],
        'env' => [
                [
                                'name' => '',
                                'value' => ''
                ]
        ],
        'image' => '',
        'ports' => [
                [
                                'containerPort' => 0
                ]
        ]
    ],
    'createTime' => '',
    'deploymentUri' => '',
    'description' => '',
    'errorMessage' => '',
    'etag' => '',
    'explanationConfig' => [
        'integratedGradientsAttribution' => [
                'numIntegralSteps' => 0
        ],
        'sampledShapleyAttribution' => [
                'numPaths' => 0
        ],
        'xraiAttribution' => [
                'numIntegralSteps' => 0
        ]
    ],
    'framework' => '',
    'isDefault' => null,
    'labels' => [
        
    ],
    'lastMigrationModelId' => '',
    'lastMigrationTime' => '',
    'lastUseTime' => '',
    'machineType' => '',
    'manualScaling' => [
        'nodes' => 0
    ],
    'name' => '',
    'packageUris' => [
        
    ],
    'predictionClass' => '',
    'pythonVersion' => '',
    'requestLoggingConfig' => [
        'bigqueryTableName' => '',
        'samplingPercentage' => ''
    ],
    'routes' => [
        'health' => '',
        'predict' => ''
    ],
    'runtimeVersion' => '',
    'serviceAccount' => '',
    'state' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:parent/versions', [
  'body' => '{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:parent/versions');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'acceleratorConfig' => [
    'count' => '',
    'type' => ''
  ],
  'autoScaling' => [
    'maxNodes' => 0,
    'metrics' => [
        [
                'name' => '',
                'target' => 0
        ]
    ],
    'minNodes' => 0
  ],
  'container' => [
    'args' => [
        
    ],
    'command' => [
        
    ],
    'env' => [
        [
                'name' => '',
                'value' => ''
        ]
    ],
    'image' => '',
    'ports' => [
        [
                'containerPort' => 0
        ]
    ]
  ],
  'createTime' => '',
  'deploymentUri' => '',
  'description' => '',
  'errorMessage' => '',
  'etag' => '',
  'explanationConfig' => [
    'integratedGradientsAttribution' => [
        'numIntegralSteps' => 0
    ],
    'sampledShapleyAttribution' => [
        'numPaths' => 0
    ],
    'xraiAttribution' => [
        'numIntegralSteps' => 0
    ]
  ],
  'framework' => '',
  'isDefault' => null,
  'labels' => [
    
  ],
  'lastMigrationModelId' => '',
  'lastMigrationTime' => '',
  'lastUseTime' => '',
  'machineType' => '',
  'manualScaling' => [
    'nodes' => 0
  ],
  'name' => '',
  'packageUris' => [
    
  ],
  'predictionClass' => '',
  'pythonVersion' => '',
  'requestLoggingConfig' => [
    'bigqueryTableName' => '',
    'samplingPercentage' => ''
  ],
  'routes' => [
    'health' => '',
    'predict' => ''
  ],
  'runtimeVersion' => '',
  'serviceAccount' => '',
  'state' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'acceleratorConfig' => [
    'count' => '',
    'type' => ''
  ],
  'autoScaling' => [
    'maxNodes' => 0,
    'metrics' => [
        [
                'name' => '',
                'target' => 0
        ]
    ],
    'minNodes' => 0
  ],
  'container' => [
    'args' => [
        
    ],
    'command' => [
        
    ],
    'env' => [
        [
                'name' => '',
                'value' => ''
        ]
    ],
    'image' => '',
    'ports' => [
        [
                'containerPort' => 0
        ]
    ]
  ],
  'createTime' => '',
  'deploymentUri' => '',
  'description' => '',
  'errorMessage' => '',
  'etag' => '',
  'explanationConfig' => [
    'integratedGradientsAttribution' => [
        'numIntegralSteps' => 0
    ],
    'sampledShapleyAttribution' => [
        'numPaths' => 0
    ],
    'xraiAttribution' => [
        'numIntegralSteps' => 0
    ]
  ],
  'framework' => '',
  'isDefault' => null,
  'labels' => [
    
  ],
  'lastMigrationModelId' => '',
  'lastMigrationTime' => '',
  'lastUseTime' => '',
  'machineType' => '',
  'manualScaling' => [
    'nodes' => 0
  ],
  'name' => '',
  'packageUris' => [
    
  ],
  'predictionClass' => '',
  'pythonVersion' => '',
  'requestLoggingConfig' => [
    'bigqueryTableName' => '',
    'samplingPercentage' => ''
  ],
  'routes' => [
    'health' => '',
    'predict' => ''
  ],
  'runtimeVersion' => '',
  'serviceAccount' => '',
  'state' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1/:parent/versions');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:parent/versions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:parent/versions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1/:parent/versions", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:parent/versions"

payload = {
    "acceleratorConfig": {
        "count": "",
        "type": ""
    },
    "autoScaling": {
        "maxNodes": 0,
        "metrics": [
            {
                "name": "",
                "target": 0
            }
        ],
        "minNodes": 0
    },
    "container": {
        "args": [],
        "command": [],
        "env": [
            {
                "name": "",
                "value": ""
            }
        ],
        "image": "",
        "ports": [{ "containerPort": 0 }]
    },
    "createTime": "",
    "deploymentUri": "",
    "description": "",
    "errorMessage": "",
    "etag": "",
    "explanationConfig": {
        "integratedGradientsAttribution": { "numIntegralSteps": 0 },
        "sampledShapleyAttribution": { "numPaths": 0 },
        "xraiAttribution": { "numIntegralSteps": 0 }
    },
    "framework": "",
    "isDefault": False,
    "labels": {},
    "lastMigrationModelId": "",
    "lastMigrationTime": "",
    "lastUseTime": "",
    "machineType": "",
    "manualScaling": { "nodes": 0 },
    "name": "",
    "packageUris": [],
    "predictionClass": "",
    "pythonVersion": "",
    "requestLoggingConfig": {
        "bigqueryTableName": "",
        "samplingPercentage": ""
    },
    "routes": {
        "health": "",
        "predict": ""
    },
    "runtimeVersion": "",
    "serviceAccount": "",
    "state": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:parent/versions"

payload <- "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/:parent/versions")

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  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v1/:parent/versions') do |req|
  req.body = "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:parent/versions";

    let payload = json!({
        "acceleratorConfig": json!({
            "count": "",
            "type": ""
        }),
        "autoScaling": json!({
            "maxNodes": 0,
            "metrics": (
                json!({
                    "name": "",
                    "target": 0
                })
            ),
            "minNodes": 0
        }),
        "container": json!({
            "args": (),
            "command": (),
            "env": (
                json!({
                    "name": "",
                    "value": ""
                })
            ),
            "image": "",
            "ports": (json!({"containerPort": 0}))
        }),
        "createTime": "",
        "deploymentUri": "",
        "description": "",
        "errorMessage": "",
        "etag": "",
        "explanationConfig": json!({
            "integratedGradientsAttribution": json!({"numIntegralSteps": 0}),
            "sampledShapleyAttribution": json!({"numPaths": 0}),
            "xraiAttribution": json!({"numIntegralSteps": 0})
        }),
        "framework": "",
        "isDefault": false,
        "labels": json!({}),
        "lastMigrationModelId": "",
        "lastMigrationTime": "",
        "lastUseTime": "",
        "machineType": "",
        "manualScaling": json!({"nodes": 0}),
        "name": "",
        "packageUris": (),
        "predictionClass": "",
        "pythonVersion": "",
        "requestLoggingConfig": json!({
            "bigqueryTableName": "",
            "samplingPercentage": ""
        }),
        "routes": json!({
            "health": "",
            "predict": ""
        }),
        "runtimeVersion": "",
        "serviceAccount": "",
        "state": ""
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:parent/versions \
  --header 'content-type: application/json' \
  --data '{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}'
echo '{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}' |  \
  http POST {{baseUrl}}/v1/:parent/versions \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "acceleratorConfig": {\n    "count": "",\n    "type": ""\n  },\n  "autoScaling": {\n    "maxNodes": 0,\n    "metrics": [\n      {\n        "name": "",\n        "target": 0\n      }\n    ],\n    "minNodes": 0\n  },\n  "container": {\n    "args": [],\n    "command": [],\n    "env": [\n      {\n        "name": "",\n        "value": ""\n      }\n    ],\n    "image": "",\n    "ports": [\n      {\n        "containerPort": 0\n      }\n    ]\n  },\n  "createTime": "",\n  "deploymentUri": "",\n  "description": "",\n  "errorMessage": "",\n  "etag": "",\n  "explanationConfig": {\n    "integratedGradientsAttribution": {\n      "numIntegralSteps": 0\n    },\n    "sampledShapleyAttribution": {\n      "numPaths": 0\n    },\n    "xraiAttribution": {\n      "numIntegralSteps": 0\n    }\n  },\n  "framework": "",\n  "isDefault": false,\n  "labels": {},\n  "lastMigrationModelId": "",\n  "lastMigrationTime": "",\n  "lastUseTime": "",\n  "machineType": "",\n  "manualScaling": {\n    "nodes": 0\n  },\n  "name": "",\n  "packageUris": [],\n  "predictionClass": "",\n  "pythonVersion": "",\n  "requestLoggingConfig": {\n    "bigqueryTableName": "",\n    "samplingPercentage": ""\n  },\n  "routes": {\n    "health": "",\n    "predict": ""\n  },\n  "runtimeVersion": "",\n  "serviceAccount": "",\n  "state": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1/:parent/versions
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "acceleratorConfig": [
    "count": "",
    "type": ""
  ],
  "autoScaling": [
    "maxNodes": 0,
    "metrics": [
      [
        "name": "",
        "target": 0
      ]
    ],
    "minNodes": 0
  ],
  "container": [
    "args": [],
    "command": [],
    "env": [
      [
        "name": "",
        "value": ""
      ]
    ],
    "image": "",
    "ports": [["containerPort": 0]]
  ],
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": [
    "integratedGradientsAttribution": ["numIntegralSteps": 0],
    "sampledShapleyAttribution": ["numPaths": 0],
    "xraiAttribution": ["numIntegralSteps": 0]
  ],
  "framework": "",
  "isDefault": false,
  "labels": [],
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": ["nodes": 0],
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": [
    "bigqueryTableName": "",
    "samplingPercentage": ""
  ],
  "routes": [
    "health": "",
    "predict": ""
  ],
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:parent/versions")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as 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 ml.projects.models.versions.delete
{{baseUrl}}/v1/: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}}/v1/:name");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/v1/:name")
require "http/client"

url = "{{baseUrl}}/v1/: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}}/v1/:name"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:name");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/: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/v1/:name HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/v1/:name")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/: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}}/v1/:name")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/v1/: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}}/v1/:name');

xhr.send(data);
import axios from 'axios';

const options = {method: 'DELETE', url: '{{baseUrl}}/v1/:name'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/: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}}/v1/:name',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1/: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/v1/: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}}/v1/: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}}/v1/: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}}/v1/:name'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/: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}}/v1/: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}}/v1/:name" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/: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}}/v1/:name');

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:name');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1/:name');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:name' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/v1/:name")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:name"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:name"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/: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/v1/: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}}/v1/: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}}/v1/:name
http DELETE {{baseUrl}}/v1/:name
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/v1/:name
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/: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 ml.projects.models.versions.list
{{baseUrl}}/v1/:parent/versions
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:parent/versions");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1/:parent/versions")
require "http/client"

url = "{{baseUrl}}/v1/:parent/versions"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/v1/:parent/versions"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:parent/versions");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:parent/versions"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/v1/:parent/versions HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1/:parent/versions")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:parent/versions"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:parent/versions")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1/:parent/versions")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v1/:parent/versions');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/versions'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:parent/versions';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:parent/versions',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1/:parent/versions")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:parent/versions',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/versions'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1/:parent/versions');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/v1/:parent/versions'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:parent/versions';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:parent/versions"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1/:parent/versions" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:parent/versions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v1/:parent/versions');

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:parent/versions');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1/:parent/versions');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:parent/versions' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:parent/versions' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1/:parent/versions")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:parent/versions"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:parent/versions"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/:parent/versions")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/v1/:parent/versions') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:parent/versions";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v1/:parent/versions
http GET {{baseUrl}}/v1/:parent/versions
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1/:parent/versions
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:parent/versions")! 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 ml.projects.models.versions.patch
{{baseUrl}}/v1/:name
QUERY PARAMS

name
BODY json

{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/: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  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/patch "{{baseUrl}}/v1/:name" {:content-type :json
                                                      :form-params {:acceleratorConfig {:count ""
                                                                                        :type ""}
                                                                    :autoScaling {:maxNodes 0
                                                                                  :metrics [{:name ""
                                                                                             :target 0}]
                                                                                  :minNodes 0}
                                                                    :container {:args []
                                                                                :command []
                                                                                :env [{:name ""
                                                                                       :value ""}]
                                                                                :image ""
                                                                                :ports [{:containerPort 0}]}
                                                                    :createTime ""
                                                                    :deploymentUri ""
                                                                    :description ""
                                                                    :errorMessage ""
                                                                    :etag ""
                                                                    :explanationConfig {:integratedGradientsAttribution {:numIntegralSteps 0}
                                                                                        :sampledShapleyAttribution {:numPaths 0}
                                                                                        :xraiAttribution {:numIntegralSteps 0}}
                                                                    :framework ""
                                                                    :isDefault false
                                                                    :labels {}
                                                                    :lastMigrationModelId ""
                                                                    :lastMigrationTime ""
                                                                    :lastUseTime ""
                                                                    :machineType ""
                                                                    :manualScaling {:nodes 0}
                                                                    :name ""
                                                                    :packageUris []
                                                                    :predictionClass ""
                                                                    :pythonVersion ""
                                                                    :requestLoggingConfig {:bigqueryTableName ""
                                                                                           :samplingPercentage ""}
                                                                    :routes {:health ""
                                                                             :predict ""}
                                                                    :runtimeVersion ""
                                                                    :serviceAccount ""
                                                                    :state ""}})
require "http/client"

url = "{{baseUrl}}/v1/:name"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\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}}/v1/:name"),
    Content = new StringContent("{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:name");
var request = new RestRequest("", Method.Patch);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:name"

	payload := strings.NewReader("{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\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/v1/:name HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1234

{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/v1/:name")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:name"))
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:name")
  .patch(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/v1/:name")
  .header("content-type", "application/json")
  .body("{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  acceleratorConfig: {
    count: '',
    type: ''
  },
  autoScaling: {
    maxNodes: 0,
    metrics: [
      {
        name: '',
        target: 0
      }
    ],
    minNodes: 0
  },
  container: {
    args: [],
    command: [],
    env: [
      {
        name: '',
        value: ''
      }
    ],
    image: '',
    ports: [
      {
        containerPort: 0
      }
    ]
  },
  createTime: '',
  deploymentUri: '',
  description: '',
  errorMessage: '',
  etag: '',
  explanationConfig: {
    integratedGradientsAttribution: {
      numIntegralSteps: 0
    },
    sampledShapleyAttribution: {
      numPaths: 0
    },
    xraiAttribution: {
      numIntegralSteps: 0
    }
  },
  framework: '',
  isDefault: false,
  labels: {},
  lastMigrationModelId: '',
  lastMigrationTime: '',
  lastUseTime: '',
  machineType: '',
  manualScaling: {
    nodes: 0
  },
  name: '',
  packageUris: [],
  predictionClass: '',
  pythonVersion: '',
  requestLoggingConfig: {
    bigqueryTableName: '',
    samplingPercentage: ''
  },
  routes: {
    health: '',
    predict: ''
  },
  runtimeVersion: '',
  serviceAccount: '',
  state: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PATCH', '{{baseUrl}}/v1/:name');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/v1/:name',
  headers: {'content-type': 'application/json'},
  data: {
    acceleratorConfig: {count: '', type: ''},
    autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
    container: {
      args: [],
      command: [],
      env: [{name: '', value: ''}],
      image: '',
      ports: [{containerPort: 0}]
    },
    createTime: '',
    deploymentUri: '',
    description: '',
    errorMessage: '',
    etag: '',
    explanationConfig: {
      integratedGradientsAttribution: {numIntegralSteps: 0},
      sampledShapleyAttribution: {numPaths: 0},
      xraiAttribution: {numIntegralSteps: 0}
    },
    framework: '',
    isDefault: false,
    labels: {},
    lastMigrationModelId: '',
    lastMigrationTime: '',
    lastUseTime: '',
    machineType: '',
    manualScaling: {nodes: 0},
    name: '',
    packageUris: [],
    predictionClass: '',
    pythonVersion: '',
    requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
    routes: {health: '', predict: ''},
    runtimeVersion: '',
    serviceAccount: '',
    state: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:name';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"acceleratorConfig":{"count":"","type":""},"autoScaling":{"maxNodes":0,"metrics":[{"name":"","target":0}],"minNodes":0},"container":{"args":[],"command":[],"env":[{"name":"","value":""}],"image":"","ports":[{"containerPort":0}]},"createTime":"","deploymentUri":"","description":"","errorMessage":"","etag":"","explanationConfig":{"integratedGradientsAttribution":{"numIntegralSteps":0},"sampledShapleyAttribution":{"numPaths":0},"xraiAttribution":{"numIntegralSteps":0}},"framework":"","isDefault":false,"labels":{},"lastMigrationModelId":"","lastMigrationTime":"","lastUseTime":"","machineType":"","manualScaling":{"nodes":0},"name":"","packageUris":[],"predictionClass":"","pythonVersion":"","requestLoggingConfig":{"bigqueryTableName":"","samplingPercentage":""},"routes":{"health":"","predict":""},"runtimeVersion":"","serviceAccount":"","state":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:name',
  method: 'PATCH',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "acceleratorConfig": {\n    "count": "",\n    "type": ""\n  },\n  "autoScaling": {\n    "maxNodes": 0,\n    "metrics": [\n      {\n        "name": "",\n        "target": 0\n      }\n    ],\n    "minNodes": 0\n  },\n  "container": {\n    "args": [],\n    "command": [],\n    "env": [\n      {\n        "name": "",\n        "value": ""\n      }\n    ],\n    "image": "",\n    "ports": [\n      {\n        "containerPort": 0\n      }\n    ]\n  },\n  "createTime": "",\n  "deploymentUri": "",\n  "description": "",\n  "errorMessage": "",\n  "etag": "",\n  "explanationConfig": {\n    "integratedGradientsAttribution": {\n      "numIntegralSteps": 0\n    },\n    "sampledShapleyAttribution": {\n      "numPaths": 0\n    },\n    "xraiAttribution": {\n      "numIntegralSteps": 0\n    }\n  },\n  "framework": "",\n  "isDefault": false,\n  "labels": {},\n  "lastMigrationModelId": "",\n  "lastMigrationTime": "",\n  "lastUseTime": "",\n  "machineType": "",\n  "manualScaling": {\n    "nodes": 0\n  },\n  "name": "",\n  "packageUris": [],\n  "predictionClass": "",\n  "pythonVersion": "",\n  "requestLoggingConfig": {\n    "bigqueryTableName": "",\n    "samplingPercentage": ""\n  },\n  "routes": {\n    "health": "",\n    "predict": ""\n  },\n  "runtimeVersion": "",\n  "serviceAccount": "",\n  "state": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/: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/v1/: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({
  acceleratorConfig: {count: '', type: ''},
  autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
  container: {
    args: [],
    command: [],
    env: [{name: '', value: ''}],
    image: '',
    ports: [{containerPort: 0}]
  },
  createTime: '',
  deploymentUri: '',
  description: '',
  errorMessage: '',
  etag: '',
  explanationConfig: {
    integratedGradientsAttribution: {numIntegralSteps: 0},
    sampledShapleyAttribution: {numPaths: 0},
    xraiAttribution: {numIntegralSteps: 0}
  },
  framework: '',
  isDefault: false,
  labels: {},
  lastMigrationModelId: '',
  lastMigrationTime: '',
  lastUseTime: '',
  machineType: '',
  manualScaling: {nodes: 0},
  name: '',
  packageUris: [],
  predictionClass: '',
  pythonVersion: '',
  requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
  routes: {health: '', predict: ''},
  runtimeVersion: '',
  serviceAccount: '',
  state: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/v1/:name',
  headers: {'content-type': 'application/json'},
  body: {
    acceleratorConfig: {count: '', type: ''},
    autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
    container: {
      args: [],
      command: [],
      env: [{name: '', value: ''}],
      image: '',
      ports: [{containerPort: 0}]
    },
    createTime: '',
    deploymentUri: '',
    description: '',
    errorMessage: '',
    etag: '',
    explanationConfig: {
      integratedGradientsAttribution: {numIntegralSteps: 0},
      sampledShapleyAttribution: {numPaths: 0},
      xraiAttribution: {numIntegralSteps: 0}
    },
    framework: '',
    isDefault: false,
    labels: {},
    lastMigrationModelId: '',
    lastMigrationTime: '',
    lastUseTime: '',
    machineType: '',
    manualScaling: {nodes: 0},
    name: '',
    packageUris: [],
    predictionClass: '',
    pythonVersion: '',
    requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
    routes: {health: '', predict: ''},
    runtimeVersion: '',
    serviceAccount: '',
    state: ''
  },
  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}}/v1/:name');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  acceleratorConfig: {
    count: '',
    type: ''
  },
  autoScaling: {
    maxNodes: 0,
    metrics: [
      {
        name: '',
        target: 0
      }
    ],
    minNodes: 0
  },
  container: {
    args: [],
    command: [],
    env: [
      {
        name: '',
        value: ''
      }
    ],
    image: '',
    ports: [
      {
        containerPort: 0
      }
    ]
  },
  createTime: '',
  deploymentUri: '',
  description: '',
  errorMessage: '',
  etag: '',
  explanationConfig: {
    integratedGradientsAttribution: {
      numIntegralSteps: 0
    },
    sampledShapleyAttribution: {
      numPaths: 0
    },
    xraiAttribution: {
      numIntegralSteps: 0
    }
  },
  framework: '',
  isDefault: false,
  labels: {},
  lastMigrationModelId: '',
  lastMigrationTime: '',
  lastUseTime: '',
  machineType: '',
  manualScaling: {
    nodes: 0
  },
  name: '',
  packageUris: [],
  predictionClass: '',
  pythonVersion: '',
  requestLoggingConfig: {
    bigqueryTableName: '',
    samplingPercentage: ''
  },
  routes: {
    health: '',
    predict: ''
  },
  runtimeVersion: '',
  serviceAccount: '',
  state: ''
});

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}}/v1/:name',
  headers: {'content-type': 'application/json'},
  data: {
    acceleratorConfig: {count: '', type: ''},
    autoScaling: {maxNodes: 0, metrics: [{name: '', target: 0}], minNodes: 0},
    container: {
      args: [],
      command: [],
      env: [{name: '', value: ''}],
      image: '',
      ports: [{containerPort: 0}]
    },
    createTime: '',
    deploymentUri: '',
    description: '',
    errorMessage: '',
    etag: '',
    explanationConfig: {
      integratedGradientsAttribution: {numIntegralSteps: 0},
      sampledShapleyAttribution: {numPaths: 0},
      xraiAttribution: {numIntegralSteps: 0}
    },
    framework: '',
    isDefault: false,
    labels: {},
    lastMigrationModelId: '',
    lastMigrationTime: '',
    lastUseTime: '',
    machineType: '',
    manualScaling: {nodes: 0},
    name: '',
    packageUris: [],
    predictionClass: '',
    pythonVersion: '',
    requestLoggingConfig: {bigqueryTableName: '', samplingPercentage: ''},
    routes: {health: '', predict: ''},
    runtimeVersion: '',
    serviceAccount: '',
    state: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:name';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"acceleratorConfig":{"count":"","type":""},"autoScaling":{"maxNodes":0,"metrics":[{"name":"","target":0}],"minNodes":0},"container":{"args":[],"command":[],"env":[{"name":"","value":""}],"image":"","ports":[{"containerPort":0}]},"createTime":"","deploymentUri":"","description":"","errorMessage":"","etag":"","explanationConfig":{"integratedGradientsAttribution":{"numIntegralSteps":0},"sampledShapleyAttribution":{"numPaths":0},"xraiAttribution":{"numIntegralSteps":0}},"framework":"","isDefault":false,"labels":{},"lastMigrationModelId":"","lastMigrationTime":"","lastUseTime":"","machineType":"","manualScaling":{"nodes":0},"name":"","packageUris":[],"predictionClass":"","pythonVersion":"","requestLoggingConfig":{"bigqueryTableName":"","samplingPercentage":""},"routes":{"health":"","predict":""},"runtimeVersion":"","serviceAccount":"","state":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"acceleratorConfig": @{ @"count": @"", @"type": @"" },
                              @"autoScaling": @{ @"maxNodes": @0, @"metrics": @[ @{ @"name": @"", @"target": @0 } ], @"minNodes": @0 },
                              @"container": @{ @"args": @[  ], @"command": @[  ], @"env": @[ @{ @"name": @"", @"value": @"" } ], @"image": @"", @"ports": @[ @{ @"containerPort": @0 } ] },
                              @"createTime": @"",
                              @"deploymentUri": @"",
                              @"description": @"",
                              @"errorMessage": @"",
                              @"etag": @"",
                              @"explanationConfig": @{ @"integratedGradientsAttribution": @{ @"numIntegralSteps": @0 }, @"sampledShapleyAttribution": @{ @"numPaths": @0 }, @"xraiAttribution": @{ @"numIntegralSteps": @0 } },
                              @"framework": @"",
                              @"isDefault": @NO,
                              @"labels": @{  },
                              @"lastMigrationModelId": @"",
                              @"lastMigrationTime": @"",
                              @"lastUseTime": @"",
                              @"machineType": @"",
                              @"manualScaling": @{ @"nodes": @0 },
                              @"name": @"",
                              @"packageUris": @[  ],
                              @"predictionClass": @"",
                              @"pythonVersion": @"",
                              @"requestLoggingConfig": @{ @"bigqueryTableName": @"", @"samplingPercentage": @"" },
                              @"routes": @{ @"health": @"", @"predict": @"" },
                              @"runtimeVersion": @"",
                              @"serviceAccount": @"",
                              @"state": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/: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}}/v1/:name" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/: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([
    'acceleratorConfig' => [
        'count' => '',
        'type' => ''
    ],
    'autoScaling' => [
        'maxNodes' => 0,
        'metrics' => [
                [
                                'name' => '',
                                'target' => 0
                ]
        ],
        'minNodes' => 0
    ],
    'container' => [
        'args' => [
                
        ],
        'command' => [
                
        ],
        'env' => [
                [
                                'name' => '',
                                'value' => ''
                ]
        ],
        'image' => '',
        'ports' => [
                [
                                'containerPort' => 0
                ]
        ]
    ],
    'createTime' => '',
    'deploymentUri' => '',
    'description' => '',
    'errorMessage' => '',
    'etag' => '',
    'explanationConfig' => [
        'integratedGradientsAttribution' => [
                'numIntegralSteps' => 0
        ],
        'sampledShapleyAttribution' => [
                'numPaths' => 0
        ],
        'xraiAttribution' => [
                'numIntegralSteps' => 0
        ]
    ],
    'framework' => '',
    'isDefault' => null,
    'labels' => [
        
    ],
    'lastMigrationModelId' => '',
    'lastMigrationTime' => '',
    'lastUseTime' => '',
    'machineType' => '',
    'manualScaling' => [
        'nodes' => 0
    ],
    'name' => '',
    'packageUris' => [
        
    ],
    'predictionClass' => '',
    'pythonVersion' => '',
    'requestLoggingConfig' => [
        'bigqueryTableName' => '',
        'samplingPercentage' => ''
    ],
    'routes' => [
        'health' => '',
        'predict' => ''
    ],
    'runtimeVersion' => '',
    'serviceAccount' => '',
    'state' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-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}}/v1/:name', [
  'body' => '{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:name');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'acceleratorConfig' => [
    'count' => '',
    'type' => ''
  ],
  'autoScaling' => [
    'maxNodes' => 0,
    'metrics' => [
        [
                'name' => '',
                'target' => 0
        ]
    ],
    'minNodes' => 0
  ],
  'container' => [
    'args' => [
        
    ],
    'command' => [
        
    ],
    'env' => [
        [
                'name' => '',
                'value' => ''
        ]
    ],
    'image' => '',
    'ports' => [
        [
                'containerPort' => 0
        ]
    ]
  ],
  'createTime' => '',
  'deploymentUri' => '',
  'description' => '',
  'errorMessage' => '',
  'etag' => '',
  'explanationConfig' => [
    'integratedGradientsAttribution' => [
        'numIntegralSteps' => 0
    ],
    'sampledShapleyAttribution' => [
        'numPaths' => 0
    ],
    'xraiAttribution' => [
        'numIntegralSteps' => 0
    ]
  ],
  'framework' => '',
  'isDefault' => null,
  'labels' => [
    
  ],
  'lastMigrationModelId' => '',
  'lastMigrationTime' => '',
  'lastUseTime' => '',
  'machineType' => '',
  'manualScaling' => [
    'nodes' => 0
  ],
  'name' => '',
  'packageUris' => [
    
  ],
  'predictionClass' => '',
  'pythonVersion' => '',
  'requestLoggingConfig' => [
    'bigqueryTableName' => '',
    'samplingPercentage' => ''
  ],
  'routes' => [
    'health' => '',
    'predict' => ''
  ],
  'runtimeVersion' => '',
  'serviceAccount' => '',
  'state' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'acceleratorConfig' => [
    'count' => '',
    'type' => ''
  ],
  'autoScaling' => [
    'maxNodes' => 0,
    'metrics' => [
        [
                'name' => '',
                'target' => 0
        ]
    ],
    'minNodes' => 0
  ],
  'container' => [
    'args' => [
        
    ],
    'command' => [
        
    ],
    'env' => [
        [
                'name' => '',
                'value' => ''
        ]
    ],
    'image' => '',
    'ports' => [
        [
                'containerPort' => 0
        ]
    ]
  ],
  'createTime' => '',
  'deploymentUri' => '',
  'description' => '',
  'errorMessage' => '',
  'etag' => '',
  'explanationConfig' => [
    'integratedGradientsAttribution' => [
        'numIntegralSteps' => 0
    ],
    'sampledShapleyAttribution' => [
        'numPaths' => 0
    ],
    'xraiAttribution' => [
        'numIntegralSteps' => 0
    ]
  ],
  'framework' => '',
  'isDefault' => null,
  'labels' => [
    
  ],
  'lastMigrationModelId' => '',
  'lastMigrationTime' => '',
  'lastUseTime' => '',
  'machineType' => '',
  'manualScaling' => [
    'nodes' => 0
  ],
  'name' => '',
  'packageUris' => [
    
  ],
  'predictionClass' => '',
  'pythonVersion' => '',
  'requestLoggingConfig' => [
    'bigqueryTableName' => '',
    'samplingPercentage' => ''
  ],
  'routes' => [
    'health' => '',
    'predict' => ''
  ],
  'runtimeVersion' => '',
  'serviceAccount' => '',
  'state' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1/: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}}/v1/:name' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PATCH", "/baseUrl/v1/:name", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:name"

payload = {
    "acceleratorConfig": {
        "count": "",
        "type": ""
    },
    "autoScaling": {
        "maxNodes": 0,
        "metrics": [
            {
                "name": "",
                "target": 0
            }
        ],
        "minNodes": 0
    },
    "container": {
        "args": [],
        "command": [],
        "env": [
            {
                "name": "",
                "value": ""
            }
        ],
        "image": "",
        "ports": [{ "containerPort": 0 }]
    },
    "createTime": "",
    "deploymentUri": "",
    "description": "",
    "errorMessage": "",
    "etag": "",
    "explanationConfig": {
        "integratedGradientsAttribution": { "numIntegralSteps": 0 },
        "sampledShapleyAttribution": { "numPaths": 0 },
        "xraiAttribution": { "numIntegralSteps": 0 }
    },
    "framework": "",
    "isDefault": False,
    "labels": {},
    "lastMigrationModelId": "",
    "lastMigrationTime": "",
    "lastUseTime": "",
    "machineType": "",
    "manualScaling": { "nodes": 0 },
    "name": "",
    "packageUris": [],
    "predictionClass": "",
    "pythonVersion": "",
    "requestLoggingConfig": {
        "bigqueryTableName": "",
        "samplingPercentage": ""
    },
    "routes": {
        "health": "",
        "predict": ""
    },
    "runtimeVersion": "",
    "serviceAccount": "",
    "state": ""
}
headers = {"content-type": "application/json"}

response = requests.patch(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:name"

payload <- "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\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}}/v1/: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  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}"

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/v1/:name') do |req|
  req.body = "{\n  \"acceleratorConfig\": {\n    \"count\": \"\",\n    \"type\": \"\"\n  },\n  \"autoScaling\": {\n    \"maxNodes\": 0,\n    \"metrics\": [\n      {\n        \"name\": \"\",\n        \"target\": 0\n      }\n    ],\n    \"minNodes\": 0\n  },\n  \"container\": {\n    \"args\": [],\n    \"command\": [],\n    \"env\": [\n      {\n        \"name\": \"\",\n        \"value\": \"\"\n      }\n    ],\n    \"image\": \"\",\n    \"ports\": [\n      {\n        \"containerPort\": 0\n      }\n    ]\n  },\n  \"createTime\": \"\",\n  \"deploymentUri\": \"\",\n  \"description\": \"\",\n  \"errorMessage\": \"\",\n  \"etag\": \"\",\n  \"explanationConfig\": {\n    \"integratedGradientsAttribution\": {\n      \"numIntegralSteps\": 0\n    },\n    \"sampledShapleyAttribution\": {\n      \"numPaths\": 0\n    },\n    \"xraiAttribution\": {\n      \"numIntegralSteps\": 0\n    }\n  },\n  \"framework\": \"\",\n  \"isDefault\": false,\n  \"labels\": {},\n  \"lastMigrationModelId\": \"\",\n  \"lastMigrationTime\": \"\",\n  \"lastUseTime\": \"\",\n  \"machineType\": \"\",\n  \"manualScaling\": {\n    \"nodes\": 0\n  },\n  \"name\": \"\",\n  \"packageUris\": [],\n  \"predictionClass\": \"\",\n  \"pythonVersion\": \"\",\n  \"requestLoggingConfig\": {\n    \"bigqueryTableName\": \"\",\n    \"samplingPercentage\": \"\"\n  },\n  \"routes\": {\n    \"health\": \"\",\n    \"predict\": \"\"\n  },\n  \"runtimeVersion\": \"\",\n  \"serviceAccount\": \"\",\n  \"state\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:name";

    let payload = json!({
        "acceleratorConfig": json!({
            "count": "",
            "type": ""
        }),
        "autoScaling": json!({
            "maxNodes": 0,
            "metrics": (
                json!({
                    "name": "",
                    "target": 0
                })
            ),
            "minNodes": 0
        }),
        "container": json!({
            "args": (),
            "command": (),
            "env": (
                json!({
                    "name": "",
                    "value": ""
                })
            ),
            "image": "",
            "ports": (json!({"containerPort": 0}))
        }),
        "createTime": "",
        "deploymentUri": "",
        "description": "",
        "errorMessage": "",
        "etag": "",
        "explanationConfig": json!({
            "integratedGradientsAttribution": json!({"numIntegralSteps": 0}),
            "sampledShapleyAttribution": json!({"numPaths": 0}),
            "xraiAttribution": json!({"numIntegralSteps": 0})
        }),
        "framework": "",
        "isDefault": false,
        "labels": json!({}),
        "lastMigrationModelId": "",
        "lastMigrationTime": "",
        "lastUseTime": "",
        "machineType": "",
        "manualScaling": json!({"nodes": 0}),
        "name": "",
        "packageUris": (),
        "predictionClass": "",
        "pythonVersion": "",
        "requestLoggingConfig": json!({
            "bigqueryTableName": "",
            "samplingPercentage": ""
        }),
        "routes": json!({
            "health": "",
            "predict": ""
        }),
        "runtimeVersion": "",
        "serviceAccount": "",
        "state": ""
    });

    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}}/v1/:name \
  --header 'content-type: application/json' \
  --data '{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}'
echo '{
  "acceleratorConfig": {
    "count": "",
    "type": ""
  },
  "autoScaling": {
    "maxNodes": 0,
    "metrics": [
      {
        "name": "",
        "target": 0
      }
    ],
    "minNodes": 0
  },
  "container": {
    "args": [],
    "command": [],
    "env": [
      {
        "name": "",
        "value": ""
      }
    ],
    "image": "",
    "ports": [
      {
        "containerPort": 0
      }
    ]
  },
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": {
    "integratedGradientsAttribution": {
      "numIntegralSteps": 0
    },
    "sampledShapleyAttribution": {
      "numPaths": 0
    },
    "xraiAttribution": {
      "numIntegralSteps": 0
    }
  },
  "framework": "",
  "isDefault": false,
  "labels": {},
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": {
    "nodes": 0
  },
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": {
    "bigqueryTableName": "",
    "samplingPercentage": ""
  },
  "routes": {
    "health": "",
    "predict": ""
  },
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
}' |  \
  http PATCH {{baseUrl}}/v1/:name \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'content-type: application/json' \
  --body-data '{\n  "acceleratorConfig": {\n    "count": "",\n    "type": ""\n  },\n  "autoScaling": {\n    "maxNodes": 0,\n    "metrics": [\n      {\n        "name": "",\n        "target": 0\n      }\n    ],\n    "minNodes": 0\n  },\n  "container": {\n    "args": [],\n    "command": [],\n    "env": [\n      {\n        "name": "",\n        "value": ""\n      }\n    ],\n    "image": "",\n    "ports": [\n      {\n        "containerPort": 0\n      }\n    ]\n  },\n  "createTime": "",\n  "deploymentUri": "",\n  "description": "",\n  "errorMessage": "",\n  "etag": "",\n  "explanationConfig": {\n    "integratedGradientsAttribution": {\n      "numIntegralSteps": 0\n    },\n    "sampledShapleyAttribution": {\n      "numPaths": 0\n    },\n    "xraiAttribution": {\n      "numIntegralSteps": 0\n    }\n  },\n  "framework": "",\n  "isDefault": false,\n  "labels": {},\n  "lastMigrationModelId": "",\n  "lastMigrationTime": "",\n  "lastUseTime": "",\n  "machineType": "",\n  "manualScaling": {\n    "nodes": 0\n  },\n  "name": "",\n  "packageUris": [],\n  "predictionClass": "",\n  "pythonVersion": "",\n  "requestLoggingConfig": {\n    "bigqueryTableName": "",\n    "samplingPercentage": ""\n  },\n  "routes": {\n    "health": "",\n    "predict": ""\n  },\n  "runtimeVersion": "",\n  "serviceAccount": "",\n  "state": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1/:name
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "acceleratorConfig": [
    "count": "",
    "type": ""
  ],
  "autoScaling": [
    "maxNodes": 0,
    "metrics": [
      [
        "name": "",
        "target": 0
      ]
    ],
    "minNodes": 0
  ],
  "container": [
    "args": [],
    "command": [],
    "env": [
      [
        "name": "",
        "value": ""
      ]
    ],
    "image": "",
    "ports": [["containerPort": 0]]
  ],
  "createTime": "",
  "deploymentUri": "",
  "description": "",
  "errorMessage": "",
  "etag": "",
  "explanationConfig": [
    "integratedGradientsAttribution": ["numIntegralSteps": 0],
    "sampledShapleyAttribution": ["numPaths": 0],
    "xraiAttribution": ["numIntegralSteps": 0]
  ],
  "framework": "",
  "isDefault": false,
  "labels": [],
  "lastMigrationModelId": "",
  "lastMigrationTime": "",
  "lastUseTime": "",
  "machineType": "",
  "manualScaling": ["nodes": 0],
  "name": "",
  "packageUris": [],
  "predictionClass": "",
  "pythonVersion": "",
  "requestLoggingConfig": [
    "bigqueryTableName": "",
    "samplingPercentage": ""
  ],
  "routes": [
    "health": "",
    "predict": ""
  ],
  "runtimeVersion": "",
  "serviceAccount": "",
  "state": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/: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()
POST ml.projects.models.versions.setDefault
{{baseUrl}}/v1/:name:setDefault
QUERY PARAMS

name
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:name:setDefault");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1/:name:setDefault" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v1/:name:setDefault"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:name:setDefault"),
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:name:setDefault");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:name:setDefault"

	payload := strings.NewReader("{}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v1/:name:setDefault HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:name:setDefault")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:name:setDefault"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:name:setDefault")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:name:setDefault")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1/:name:setDefault');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:setDefault',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:name:setDefault';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:name:setDefault',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:name:setDefault")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:name:setDefault',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:setDefault',
  headers: {'content-type': 'application/json'},
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v1/:name:setDefault');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:setDefault',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:name:setDefault';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:name:setDefault"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1/:name:setDefault" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:name:setDefault",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:name:setDefault', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:name:setDefault');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/v1/:name:setDefault');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:name:setDefault' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name:setDefault' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1/:name:setDefault", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:name:setDefault"

payload = {}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:name:setDefault"

payload <- "{}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/:name:setDefault")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v1/:name:setDefault') do |req|
  req.body = "{}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:name:setDefault";

    let payload = json!({});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:name:setDefault \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v1/:name:setDefault \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v1/:name:setDefault
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:name:setDefault")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST ml.projects.operations.cancel
{{baseUrl}}/v1/:name:cancel
QUERY PARAMS

name
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:name:cancel");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1/:name:cancel" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v1/:name:cancel"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:name:cancel"),
    Content = new StringContent("{}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:name:cancel");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:name:cancel"

	payload := strings.NewReader("{}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v1/:name:cancel HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

{}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:name:cancel")
  .setHeader("content-type", "application/json")
  .setBody("{}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:name:cancel"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:name:cancel")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:name:cancel")
  .header("content-type", "application/json")
  .body("{}")
  .asString();
const data = JSON.stringify({});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1/:name:cancel');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:cancel',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:name:cancel';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:name:cancel',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:name:cancel")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:name:cancel',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:cancel',
  headers: {'content-type': 'application/json'},
  body: {},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v1/:name:cancel');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:cancel',
  headers: {'content-type': 'application/json'},
  data: {}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:name:cancel';
const options = {method: 'POST', headers: {'content-type': 'application/json'}, body: '{}'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{  };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:name:cancel"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1/:name:cancel" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:name:cancel",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:name:cancel', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:name:cancel');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  
]));
$request->setRequestUrl('{{baseUrl}}/v1/:name:cancel');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:name:cancel' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name:cancel' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1/:name:cancel", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:name:cancel"

payload = {}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:name:cancel"

payload <- "{}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/:name:cancel")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v1/:name:cancel') do |req|
  req.body = "{}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:name:cancel";

    let payload = json!({});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:name:cancel \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v1/:name:cancel \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v1/:name:cancel
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:name:cancel")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET ml.projects.operations.get
{{baseUrl}}/v1/: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}}/v1/:name");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1/:name")
require "http/client"

url = "{{baseUrl}}/v1/: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}}/v1/:name"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:name");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/: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/v1/:name HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1/:name")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/: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}}/v1/:name")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1/: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}}/v1/:name');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/v1/:name'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/: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}}/v1/:name',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1/:name")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/: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}}/v1/: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}}/v1/: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}}/v1/:name'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/: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}}/v1/: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}}/v1/:name" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/: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}}/v1/:name');

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:name');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1/:name');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:name' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1/:name")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:name"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:name"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/: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/v1/:name') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/: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}}/v1/:name
http GET {{baseUrl}}/v1/:name
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1/:name
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:name")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET ml.projects.operations.list
{{baseUrl}}/v1/:name/operations
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:name/operations");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1/:name/operations")
require "http/client"

url = "{{baseUrl}}/v1/:name/operations"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/v1/:name/operations"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:name/operations");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:name/operations"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/v1/:name/operations HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1/:name/operations")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:name/operations"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:name/operations")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1/:name/operations")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v1/:name/operations');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/v1/:name/operations'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:name/operations';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:name/operations',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1/:name/operations")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:name/operations',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/v1/:name/operations'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1/:name/operations');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/v1/:name/operations'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:name/operations';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:name/operations"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1/:name/operations" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:name/operations",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v1/:name/operations');

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:name/operations');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1/:name/operations');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:name/operations' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name/operations' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1/:name/operations")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:name/operations"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:name/operations"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/:name/operations")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/v1/:name/operations') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:name/operations";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v1/:name/operations
http GET {{baseUrl}}/v1/:name/operations
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1/:name/operations
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:name/operations")! 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 ml.projects.predict
{{baseUrl}}/v1/:name:predict
QUERY PARAMS

name
BODY json

{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1/:name:predict");

struct curl_slist *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  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1/:name:predict" {:content-type :json
                                                             :form-params {:httpBody {:contentType ""
                                                                                      :data ""
                                                                                      :extensions [{}]}}})
require "http/client"

url = "{{baseUrl}}/v1/:name:predict"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1/:name:predict"),
    Content = new StringContent("{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1/:name:predict");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1/:name:predict"

	payload := strings.NewReader("{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v1/:name:predict HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 97

{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1/:name:predict")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1/:name:predict"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1/:name:predict")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1/:name:predict")
  .header("content-type", "application/json")
  .body("{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  httpBody: {
    contentType: '',
    data: '',
    extensions: [
      {}
    ]
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1/:name:predict');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:predict',
  headers: {'content-type': 'application/json'},
  data: {httpBody: {contentType: '', data: '', extensions: [{}]}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1/:name:predict';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"httpBody":{"contentType":"","data":"","extensions":[{}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1/:name:predict',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "httpBody": {\n    "contentType": "",\n    "data": "",\n    "extensions": [\n      {}\n    ]\n  }\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1/:name:predict")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1/:name:predict',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({httpBody: {contentType: '', data: '', extensions: [{}]}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:predict',
  headers: {'content-type': 'application/json'},
  body: {httpBody: {contentType: '', data: '', extensions: [{}]}},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v1/:name:predict');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  httpBody: {
    contentType: '',
    data: '',
    extensions: [
      {}
    ]
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1/:name:predict',
  headers: {'content-type': 'application/json'},
  data: {httpBody: {contentType: '', data: '', extensions: [{}]}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1/:name:predict';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"httpBody":{"contentType":"","data":"","extensions":[{}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"httpBody": @{ @"contentType": @"", @"data": @"", @"extensions": @[ @{  } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1/:name:predict"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1/:name:predict" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1/:name:predict",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'httpBody' => [
        'contentType' => '',
        'data' => '',
        'extensions' => [
                [
                                
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1/:name:predict', [
  'body' => '{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1/:name:predict');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'httpBody' => [
    'contentType' => '',
    'data' => '',
    'extensions' => [
        [
                
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'httpBody' => [
    'contentType' => '',
    'data' => '',
    'extensions' => [
        [
                
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v1/:name:predict');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1/:name:predict' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1/:name:predict' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1/:name:predict", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1/:name:predict"

payload = { "httpBody": {
        "contentType": "",
        "data": "",
        "extensions": [{}]
    } }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1/:name:predict"

payload <- "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1/:name:predict")

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  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v1/:name:predict') do |req|
  req.body = "{\n  \"httpBody\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1/:name:predict";

    let payload = json!({"httpBody": json!({
            "contentType": "",
            "data": "",
            "extensions": (json!({}))
        })});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1/:name:predict \
  --header 'content-type: application/json' \
  --data '{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}'
echo '{
  "httpBody": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}' |  \
  http POST {{baseUrl}}/v1/:name:predict \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "httpBody": {\n    "contentType": "",\n    "data": "",\n    "extensions": [\n      {}\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v1/:name:predict
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["httpBody": [
    "contentType": "",
    "data": "",
    "extensions": [[]]
  ]] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1/:name:predict")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()