DELETE bigquery.datasets.delete
{{baseUrl}}/projects/:projectId/datasets/:datasetId
QUERY PARAMS

projectId
datasetId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId");

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

(client/delete "{{baseUrl}}/projects/:projectId/datasets/:datasetId")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

	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/projects/:projectId/datasets/:datasetId HTTP/1.1
Host: example.com

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

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

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

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId")
  .delete(null)
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId'
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/projects/:projectId/datasets/:datasetId');

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}}/projects/:projectId/datasets/:datasetId'
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId';
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}}/projects/:projectId/datasets/:datasetId"]
                                                       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}}/projects/:projectId/datasets/:datasetId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId');
$request->setMethod(HTTP_METH_DELETE);

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

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

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

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

conn.request("DELETE", "/baseUrl/projects/:projectId/datasets/:datasetId")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

response = requests.delete(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId")

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/projects/:projectId/datasets/:datasetId') do |req|
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId";

    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}}/projects/:projectId/datasets/:datasetId
http DELETE {{baseUrl}}/projects/:projectId/datasets/:datasetId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId")! 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 bigquery.datasets.get
{{baseUrl}}/projects/:projectId/datasets/:datasetId
QUERY PARAMS

projectId
datasetId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId");

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

(client/get "{{baseUrl}}/projects/:projectId/datasets/:datasetId")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

	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/projects/:projectId/datasets/:datasetId HTTP/1.1
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:projectId/datasets/:datasetId")
  .asString();
const 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}}/projects/:projectId/datasets/:datasetId');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId'
};

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

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

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/datasets/:datasetId');

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}}/projects/:projectId/datasets/:datasetId'
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId';
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}}/projects/:projectId/datasets/:datasetId"]
                                                       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}}/projects/:projectId/datasets/:datasetId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/projects/:projectId/datasets/:datasetId")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId")

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/projects/:projectId/datasets/:datasetId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId";

    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}}/projects/:projectId/datasets/:datasetId
http GET {{baseUrl}}/projects/:projectId/datasets/:datasetId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId")! 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 bigquery.datasets.insert
{{baseUrl}}/projects/:projectId/datasets
QUERY PARAMS

projectId
BODY json

{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}");

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

(client/post "{{baseUrl}}/projects/:projectId/datasets" {:content-type :json
                                                                         :form-params {:access [{:dataset {:dataset {:datasetId ""
                                                                                                                     :projectId ""}
                                                                                                           :targetTypes []}
                                                                                                 :domain ""
                                                                                                 :groupByEmail ""
                                                                                                 :iamMember ""
                                                                                                 :role ""
                                                                                                 :routine {:datasetId ""
                                                                                                           :projectId ""
                                                                                                           :routineId ""}
                                                                                                 :specialGroup ""
                                                                                                 :userByEmail ""
                                                                                                 :view {:datasetId ""
                                                                                                        :projectId ""
                                                                                                        :tableId ""}}]
                                                                                       :creationTime ""
                                                                                       :datasetReference {}
                                                                                       :defaultCollation ""
                                                                                       :defaultEncryptionConfiguration {:kmsKeyName ""}
                                                                                       :defaultPartitionExpirationMs ""
                                                                                       :defaultRoundingMode ""
                                                                                       :defaultTableExpirationMs ""
                                                                                       :description ""
                                                                                       :etag ""
                                                                                       :friendlyName ""
                                                                                       :id ""
                                                                                       :isCaseInsensitive false
                                                                                       :kind ""
                                                                                       :labels {}
                                                                                       :lastModifiedTime ""
                                                                                       :location ""
                                                                                       :maxTimeTravelHours ""
                                                                                       :satisfiesPzs false
                                                                                       :selfLink ""
                                                                                       :storageBillingModel ""
                                                                                       :tags [{:tagKey ""
                                                                                               :tagValue ""}]}})
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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}}/projects/:projectId/datasets"),
    Content = new StringContent("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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}}/projects/:projectId/datasets");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets"

	payload := strings.NewReader("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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/projects/:projectId/datasets HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1090

{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/projects/:projectId/datasets")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/projects/:projectId/datasets")
  .header("content-type", "application/json")
  .body("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  access: [
    {
      dataset: {
        dataset: {
          datasetId: '',
          projectId: ''
        },
        targetTypes: []
      },
      domain: '',
      groupByEmail: '',
      iamMember: '',
      role: '',
      routine: {
        datasetId: '',
        projectId: '',
        routineId: ''
      },
      specialGroup: '',
      userByEmail: '',
      view: {
        datasetId: '',
        projectId: '',
        tableId: ''
      }
    }
  ],
  creationTime: '',
  datasetReference: {},
  defaultCollation: '',
  defaultEncryptionConfiguration: {
    kmsKeyName: ''
  },
  defaultPartitionExpirationMs: '',
  defaultRoundingMode: '',
  defaultTableExpirationMs: '',
  description: '',
  etag: '',
  friendlyName: '',
  id: '',
  isCaseInsensitive: false,
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  maxTimeTravelHours: '',
  satisfiesPzs: false,
  selfLink: '',
  storageBillingModel: '',
  tags: [
    {
      tagKey: '',
      tagValue: ''
    }
  ]
});

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

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

xhr.open('POST', '{{baseUrl}}/projects/:projectId/datasets');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/datasets',
  headers: {'content-type': 'application/json'},
  data: {
    access: [
      {
        dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
        domain: '',
        groupByEmail: '',
        iamMember: '',
        role: '',
        routine: {datasetId: '', projectId: '', routineId: ''},
        specialGroup: '',
        userByEmail: '',
        view: {datasetId: '', projectId: '', tableId: ''}
      }
    ],
    creationTime: '',
    datasetReference: {},
    defaultCollation: '',
    defaultEncryptionConfiguration: {kmsKeyName: ''},
    defaultPartitionExpirationMs: '',
    defaultRoundingMode: '',
    defaultTableExpirationMs: '',
    description: '',
    etag: '',
    friendlyName: '',
    id: '',
    isCaseInsensitive: false,
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    maxTimeTravelHours: '',
    satisfiesPzs: false,
    selfLink: '',
    storageBillingModel: '',
    tags: [{tagKey: '', tagValue: ''}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/datasets';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"access":[{"dataset":{"dataset":{"datasetId":"","projectId":""},"targetTypes":[]},"domain":"","groupByEmail":"","iamMember":"","role":"","routine":{"datasetId":"","projectId":"","routineId":""},"specialGroup":"","userByEmail":"","view":{"datasetId":"","projectId":"","tableId":""}}],"creationTime":"","datasetReference":{},"defaultCollation":"","defaultEncryptionConfiguration":{"kmsKeyName":""},"defaultPartitionExpirationMs":"","defaultRoundingMode":"","defaultTableExpirationMs":"","description":"","etag":"","friendlyName":"","id":"","isCaseInsensitive":false,"kind":"","labels":{},"lastModifiedTime":"","location":"","maxTimeTravelHours":"","satisfiesPzs":false,"selfLink":"","storageBillingModel":"","tags":[{"tagKey":"","tagValue":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/projects/:projectId/datasets',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "access": [\n    {\n      "dataset": {\n        "dataset": {\n          "datasetId": "",\n          "projectId": ""\n        },\n        "targetTypes": []\n      },\n      "domain": "",\n      "groupByEmail": "",\n      "iamMember": "",\n      "role": "",\n      "routine": {\n        "datasetId": "",\n        "projectId": "",\n        "routineId": ""\n      },\n      "specialGroup": "",\n      "userByEmail": "",\n      "view": {\n        "datasetId": "",\n        "projectId": "",\n        "tableId": ""\n      }\n    }\n  ],\n  "creationTime": "",\n  "datasetReference": {},\n  "defaultCollation": "",\n  "defaultEncryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "defaultPartitionExpirationMs": "",\n  "defaultRoundingMode": "",\n  "defaultTableExpirationMs": "",\n  "description": "",\n  "etag": "",\n  "friendlyName": "",\n  "id": "",\n  "isCaseInsensitive": false,\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "maxTimeTravelHours": "",\n  "satisfiesPzs": false,\n  "selfLink": "",\n  "storageBillingModel": "",\n  "tags": [\n    {\n      "tagKey": "",\n      "tagValue": ""\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  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets")
  .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/projects/:projectId/datasets',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  access: [
    {
      dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
      domain: '',
      groupByEmail: '',
      iamMember: '',
      role: '',
      routine: {datasetId: '', projectId: '', routineId: ''},
      specialGroup: '',
      userByEmail: '',
      view: {datasetId: '', projectId: '', tableId: ''}
    }
  ],
  creationTime: '',
  datasetReference: {},
  defaultCollation: '',
  defaultEncryptionConfiguration: {kmsKeyName: ''},
  defaultPartitionExpirationMs: '',
  defaultRoundingMode: '',
  defaultTableExpirationMs: '',
  description: '',
  etag: '',
  friendlyName: '',
  id: '',
  isCaseInsensitive: false,
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  maxTimeTravelHours: '',
  satisfiesPzs: false,
  selfLink: '',
  storageBillingModel: '',
  tags: [{tagKey: '', tagValue: ''}]
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/datasets',
  headers: {'content-type': 'application/json'},
  body: {
    access: [
      {
        dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
        domain: '',
        groupByEmail: '',
        iamMember: '',
        role: '',
        routine: {datasetId: '', projectId: '', routineId: ''},
        specialGroup: '',
        userByEmail: '',
        view: {datasetId: '', projectId: '', tableId: ''}
      }
    ],
    creationTime: '',
    datasetReference: {},
    defaultCollation: '',
    defaultEncryptionConfiguration: {kmsKeyName: ''},
    defaultPartitionExpirationMs: '',
    defaultRoundingMode: '',
    defaultTableExpirationMs: '',
    description: '',
    etag: '',
    friendlyName: '',
    id: '',
    isCaseInsensitive: false,
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    maxTimeTravelHours: '',
    satisfiesPzs: false,
    selfLink: '',
    storageBillingModel: '',
    tags: [{tagKey: '', tagValue: ''}]
  },
  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}}/projects/:projectId/datasets');

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

req.type('json');
req.send({
  access: [
    {
      dataset: {
        dataset: {
          datasetId: '',
          projectId: ''
        },
        targetTypes: []
      },
      domain: '',
      groupByEmail: '',
      iamMember: '',
      role: '',
      routine: {
        datasetId: '',
        projectId: '',
        routineId: ''
      },
      specialGroup: '',
      userByEmail: '',
      view: {
        datasetId: '',
        projectId: '',
        tableId: ''
      }
    }
  ],
  creationTime: '',
  datasetReference: {},
  defaultCollation: '',
  defaultEncryptionConfiguration: {
    kmsKeyName: ''
  },
  defaultPartitionExpirationMs: '',
  defaultRoundingMode: '',
  defaultTableExpirationMs: '',
  description: '',
  etag: '',
  friendlyName: '',
  id: '',
  isCaseInsensitive: false,
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  maxTimeTravelHours: '',
  satisfiesPzs: false,
  selfLink: '',
  storageBillingModel: '',
  tags: [
    {
      tagKey: '',
      tagValue: ''
    }
  ]
});

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}}/projects/:projectId/datasets',
  headers: {'content-type': 'application/json'},
  data: {
    access: [
      {
        dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
        domain: '',
        groupByEmail: '',
        iamMember: '',
        role: '',
        routine: {datasetId: '', projectId: '', routineId: ''},
        specialGroup: '',
        userByEmail: '',
        view: {datasetId: '', projectId: '', tableId: ''}
      }
    ],
    creationTime: '',
    datasetReference: {},
    defaultCollation: '',
    defaultEncryptionConfiguration: {kmsKeyName: ''},
    defaultPartitionExpirationMs: '',
    defaultRoundingMode: '',
    defaultTableExpirationMs: '',
    description: '',
    etag: '',
    friendlyName: '',
    id: '',
    isCaseInsensitive: false,
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    maxTimeTravelHours: '',
    satisfiesPzs: false,
    selfLink: '',
    storageBillingModel: '',
    tags: [{tagKey: '', tagValue: ''}]
  }
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"access":[{"dataset":{"dataset":{"datasetId":"","projectId":""},"targetTypes":[]},"domain":"","groupByEmail":"","iamMember":"","role":"","routine":{"datasetId":"","projectId":"","routineId":""},"specialGroup":"","userByEmail":"","view":{"datasetId":"","projectId":"","tableId":""}}],"creationTime":"","datasetReference":{},"defaultCollation":"","defaultEncryptionConfiguration":{"kmsKeyName":""},"defaultPartitionExpirationMs":"","defaultRoundingMode":"","defaultTableExpirationMs":"","description":"","etag":"","friendlyName":"","id":"","isCaseInsensitive":false,"kind":"","labels":{},"lastModifiedTime":"","location":"","maxTimeTravelHours":"","satisfiesPzs":false,"selfLink":"","storageBillingModel":"","tags":[{"tagKey":"","tagValue":""}]}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"access": @[ @{ @"dataset": @{ @"dataset": @{ @"datasetId": @"", @"projectId": @"" }, @"targetTypes": @[  ] }, @"domain": @"", @"groupByEmail": @"", @"iamMember": @"", @"role": @"", @"routine": @{ @"datasetId": @"", @"projectId": @"", @"routineId": @"" }, @"specialGroup": @"", @"userByEmail": @"", @"view": @{ @"datasetId": @"", @"projectId": @"", @"tableId": @"" } } ],
                              @"creationTime": @"",
                              @"datasetReference": @{  },
                              @"defaultCollation": @"",
                              @"defaultEncryptionConfiguration": @{ @"kmsKeyName": @"" },
                              @"defaultPartitionExpirationMs": @"",
                              @"defaultRoundingMode": @"",
                              @"defaultTableExpirationMs": @"",
                              @"description": @"",
                              @"etag": @"",
                              @"friendlyName": @"",
                              @"id": @"",
                              @"isCaseInsensitive": @NO,
                              @"kind": @"",
                              @"labels": @{  },
                              @"lastModifiedTime": @"",
                              @"location": @"",
                              @"maxTimeTravelHours": @"",
                              @"satisfiesPzs": @NO,
                              @"selfLink": @"",
                              @"storageBillingModel": @"",
                              @"tags": @[ @{ @"tagKey": @"", @"tagValue": @"" } ] };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/datasets"]
                                                       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}}/projects/:projectId/datasets" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets",
  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([
    'access' => [
        [
                'dataset' => [
                                'dataset' => [
                                                                'datasetId' => '',
                                                                'projectId' => ''
                                ],
                                'targetTypes' => [
                                                                
                                ]
                ],
                'domain' => '',
                'groupByEmail' => '',
                'iamMember' => '',
                'role' => '',
                'routine' => [
                                'datasetId' => '',
                                'projectId' => '',
                                'routineId' => ''
                ],
                'specialGroup' => '',
                'userByEmail' => '',
                'view' => [
                                'datasetId' => '',
                                'projectId' => '',
                                'tableId' => ''
                ]
        ]
    ],
    'creationTime' => '',
    'datasetReference' => [
        
    ],
    'defaultCollation' => '',
    'defaultEncryptionConfiguration' => [
        'kmsKeyName' => ''
    ],
    'defaultPartitionExpirationMs' => '',
    'defaultRoundingMode' => '',
    'defaultTableExpirationMs' => '',
    'description' => '',
    'etag' => '',
    'friendlyName' => '',
    'id' => '',
    'isCaseInsensitive' => null,
    'kind' => '',
    'labels' => [
        
    ],
    'lastModifiedTime' => '',
    'location' => '',
    'maxTimeTravelHours' => '',
    'satisfiesPzs' => null,
    'selfLink' => '',
    'storageBillingModel' => '',
    'tags' => [
        [
                'tagKey' => '',
                'tagValue' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-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}}/projects/:projectId/datasets', [
  'body' => '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'access' => [
    [
        'dataset' => [
                'dataset' => [
                                'datasetId' => '',
                                'projectId' => ''
                ],
                'targetTypes' => [
                                
                ]
        ],
        'domain' => '',
        'groupByEmail' => '',
        'iamMember' => '',
        'role' => '',
        'routine' => [
                'datasetId' => '',
                'projectId' => '',
                'routineId' => ''
        ],
        'specialGroup' => '',
        'userByEmail' => '',
        'view' => [
                'datasetId' => '',
                'projectId' => '',
                'tableId' => ''
        ]
    ]
  ],
  'creationTime' => '',
  'datasetReference' => [
    
  ],
  'defaultCollation' => '',
  'defaultEncryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'defaultPartitionExpirationMs' => '',
  'defaultRoundingMode' => '',
  'defaultTableExpirationMs' => '',
  'description' => '',
  'etag' => '',
  'friendlyName' => '',
  'id' => '',
  'isCaseInsensitive' => null,
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'maxTimeTravelHours' => '',
  'satisfiesPzs' => null,
  'selfLink' => '',
  'storageBillingModel' => '',
  'tags' => [
    [
        'tagKey' => '',
        'tagValue' => ''
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'access' => [
    [
        'dataset' => [
                'dataset' => [
                                'datasetId' => '',
                                'projectId' => ''
                ],
                'targetTypes' => [
                                
                ]
        ],
        'domain' => '',
        'groupByEmail' => '',
        'iamMember' => '',
        'role' => '',
        'routine' => [
                'datasetId' => '',
                'projectId' => '',
                'routineId' => ''
        ],
        'specialGroup' => '',
        'userByEmail' => '',
        'view' => [
                'datasetId' => '',
                'projectId' => '',
                'tableId' => ''
        ]
    ]
  ],
  'creationTime' => '',
  'datasetReference' => [
    
  ],
  'defaultCollation' => '',
  'defaultEncryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'defaultPartitionExpirationMs' => '',
  'defaultRoundingMode' => '',
  'defaultTableExpirationMs' => '',
  'description' => '',
  'etag' => '',
  'friendlyName' => '',
  'id' => '',
  'isCaseInsensitive' => null,
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'maxTimeTravelHours' => '',
  'satisfiesPzs' => null,
  'selfLink' => '',
  'storageBillingModel' => '',
  'tags' => [
    [
        'tagKey' => '',
        'tagValue' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/projects/:projectId/datasets');
$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}}/projects/:projectId/datasets' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}'
import http.client

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

payload = "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}"

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

conn.request("POST", "/baseUrl/projects/:projectId/datasets", payload, headers)

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

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

url = "{{baseUrl}}/projects/:projectId/datasets"

payload = {
    "access": [
        {
            "dataset": {
                "dataset": {
                    "datasetId": "",
                    "projectId": ""
                },
                "targetTypes": []
            },
            "domain": "",
            "groupByEmail": "",
            "iamMember": "",
            "role": "",
            "routine": {
                "datasetId": "",
                "projectId": "",
                "routineId": ""
            },
            "specialGroup": "",
            "userByEmail": "",
            "view": {
                "datasetId": "",
                "projectId": "",
                "tableId": ""
            }
        }
    ],
    "creationTime": "",
    "datasetReference": {},
    "defaultCollation": "",
    "defaultEncryptionConfiguration": { "kmsKeyName": "" },
    "defaultPartitionExpirationMs": "",
    "defaultRoundingMode": "",
    "defaultTableExpirationMs": "",
    "description": "",
    "etag": "",
    "friendlyName": "",
    "id": "",
    "isCaseInsensitive": False,
    "kind": "",
    "labels": {},
    "lastModifiedTime": "",
    "location": "",
    "maxTimeTravelHours": "",
    "satisfiesPzs": False,
    "selfLink": "",
    "storageBillingModel": "",
    "tags": [
        {
            "tagKey": "",
            "tagValue": ""
        }
    ]
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/projects/:projectId/datasets"

payload <- "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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}}/projects/:projectId/datasets")

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  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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/projects/:projectId/datasets') do |req|
  req.body = "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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}}/projects/:projectId/datasets";

    let payload = json!({
        "access": (
            json!({
                "dataset": json!({
                    "dataset": json!({
                        "datasetId": "",
                        "projectId": ""
                    }),
                    "targetTypes": ()
                }),
                "domain": "",
                "groupByEmail": "",
                "iamMember": "",
                "role": "",
                "routine": json!({
                    "datasetId": "",
                    "projectId": "",
                    "routineId": ""
                }),
                "specialGroup": "",
                "userByEmail": "",
                "view": json!({
                    "datasetId": "",
                    "projectId": "",
                    "tableId": ""
                })
            })
        ),
        "creationTime": "",
        "datasetReference": json!({}),
        "defaultCollation": "",
        "defaultEncryptionConfiguration": json!({"kmsKeyName": ""}),
        "defaultPartitionExpirationMs": "",
        "defaultRoundingMode": "",
        "defaultTableExpirationMs": "",
        "description": "",
        "etag": "",
        "friendlyName": "",
        "id": "",
        "isCaseInsensitive": false,
        "kind": "",
        "labels": json!({}),
        "lastModifiedTime": "",
        "location": "",
        "maxTimeTravelHours": "",
        "satisfiesPzs": false,
        "selfLink": "",
        "storageBillingModel": "",
        "tags": (
            json!({
                "tagKey": "",
                "tagValue": ""
            })
        )
    });

    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}}/projects/:projectId/datasets \
  --header 'content-type: application/json' \
  --data '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}'
echo '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}' |  \
  http POST {{baseUrl}}/projects/:projectId/datasets \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "access": [\n    {\n      "dataset": {\n        "dataset": {\n          "datasetId": "",\n          "projectId": ""\n        },\n        "targetTypes": []\n      },\n      "domain": "",\n      "groupByEmail": "",\n      "iamMember": "",\n      "role": "",\n      "routine": {\n        "datasetId": "",\n        "projectId": "",\n        "routineId": ""\n      },\n      "specialGroup": "",\n      "userByEmail": "",\n      "view": {\n        "datasetId": "",\n        "projectId": "",\n        "tableId": ""\n      }\n    }\n  ],\n  "creationTime": "",\n  "datasetReference": {},\n  "defaultCollation": "",\n  "defaultEncryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "defaultPartitionExpirationMs": "",\n  "defaultRoundingMode": "",\n  "defaultTableExpirationMs": "",\n  "description": "",\n  "etag": "",\n  "friendlyName": "",\n  "id": "",\n  "isCaseInsensitive": false,\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "maxTimeTravelHours": "",\n  "satisfiesPzs": false,\n  "selfLink": "",\n  "storageBillingModel": "",\n  "tags": [\n    {\n      "tagKey": "",\n      "tagValue": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "access": [
    [
      "dataset": [
        "dataset": [
          "datasetId": "",
          "projectId": ""
        ],
        "targetTypes": []
      ],
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": [
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      ],
      "specialGroup": "",
      "userByEmail": "",
      "view": [
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      ]
    ]
  ],
  "creationTime": "",
  "datasetReference": [],
  "defaultCollation": "",
  "defaultEncryptionConfiguration": ["kmsKeyName": ""],
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": [],
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    [
      "tagKey": "",
      "tagValue": ""
    ]
  ]
] as [String : Any]

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

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

projectId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets");

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

(client/get "{{baseUrl}}/projects/:projectId/datasets")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets"

	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/projects/:projectId/datasets HTTP/1.1
Host: example.com

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/projects/:projectId/datasets'};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets'};

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

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

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/datasets');

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}}/projects/:projectId/datasets'};

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

const url = '{{baseUrl}}/projects/:projectId/datasets';
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}}/projects/:projectId/datasets"]
                                                       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}}/projects/:projectId/datasets" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/projects/:projectId/datasets")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets")

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/projects/:projectId/datasets') do |req|
end

puts response.status
puts response.body
use reqwest;

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

    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}}/projects/:projectId/datasets
http GET {{baseUrl}}/projects/:projectId/datasets
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets")! 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 bigquery.datasets.patch
{{baseUrl}}/projects/:projectId/datasets/:datasetId
QUERY PARAMS

projectId
datasetId
BODY json

{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}");

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

(client/patch "{{baseUrl}}/projects/:projectId/datasets/:datasetId" {:content-type :json
                                                                                     :form-params {:access [{:dataset {:dataset {:datasetId ""
                                                                                                                                 :projectId ""}
                                                                                                                       :targetTypes []}
                                                                                                             :domain ""
                                                                                                             :groupByEmail ""
                                                                                                             :iamMember ""
                                                                                                             :role ""
                                                                                                             :routine {:datasetId ""
                                                                                                                       :projectId ""
                                                                                                                       :routineId ""}
                                                                                                             :specialGroup ""
                                                                                                             :userByEmail ""
                                                                                                             :view {:datasetId ""
                                                                                                                    :projectId ""
                                                                                                                    :tableId ""}}]
                                                                                                   :creationTime ""
                                                                                                   :datasetReference {}
                                                                                                   :defaultCollation ""
                                                                                                   :defaultEncryptionConfiguration {:kmsKeyName ""}
                                                                                                   :defaultPartitionExpirationMs ""
                                                                                                   :defaultRoundingMode ""
                                                                                                   :defaultTableExpirationMs ""
                                                                                                   :description ""
                                                                                                   :etag ""
                                                                                                   :friendlyName ""
                                                                                                   :id ""
                                                                                                   :isCaseInsensitive false
                                                                                                   :kind ""
                                                                                                   :labels {}
                                                                                                   :lastModifiedTime ""
                                                                                                   :location ""
                                                                                                   :maxTimeTravelHours ""
                                                                                                   :satisfiesPzs false
                                                                                                   :selfLink ""
                                                                                                   :storageBillingModel ""
                                                                                                   :tags [{:tagKey ""
                                                                                                           :tagValue ""}]}})
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\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}}/projects/:projectId/datasets/:datasetId"),
    Content = new StringContent("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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}}/projects/:projectId/datasets/:datasetId");
var request = new RestRequest("", Method.Patch);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

	payload := strings.NewReader("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\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/projects/:projectId/datasets/:datasetId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1090

{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/projects/:projectId/datasets/:datasetId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId"))
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId")
  .patch(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/projects/:projectId/datasets/:datasetId")
  .header("content-type", "application/json")
  .body("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  access: [
    {
      dataset: {
        dataset: {
          datasetId: '',
          projectId: ''
        },
        targetTypes: []
      },
      domain: '',
      groupByEmail: '',
      iamMember: '',
      role: '',
      routine: {
        datasetId: '',
        projectId: '',
        routineId: ''
      },
      specialGroup: '',
      userByEmail: '',
      view: {
        datasetId: '',
        projectId: '',
        tableId: ''
      }
    }
  ],
  creationTime: '',
  datasetReference: {},
  defaultCollation: '',
  defaultEncryptionConfiguration: {
    kmsKeyName: ''
  },
  defaultPartitionExpirationMs: '',
  defaultRoundingMode: '',
  defaultTableExpirationMs: '',
  description: '',
  etag: '',
  friendlyName: '',
  id: '',
  isCaseInsensitive: false,
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  maxTimeTravelHours: '',
  satisfiesPzs: false,
  selfLink: '',
  storageBillingModel: '',
  tags: [
    {
      tagKey: '',
      tagValue: ''
    }
  ]
});

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

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

xhr.open('PATCH', '{{baseUrl}}/projects/:projectId/datasets/:datasetId');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId',
  headers: {'content-type': 'application/json'},
  data: {
    access: [
      {
        dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
        domain: '',
        groupByEmail: '',
        iamMember: '',
        role: '',
        routine: {datasetId: '', projectId: '', routineId: ''},
        specialGroup: '',
        userByEmail: '',
        view: {datasetId: '', projectId: '', tableId: ''}
      }
    ],
    creationTime: '',
    datasetReference: {},
    defaultCollation: '',
    defaultEncryptionConfiguration: {kmsKeyName: ''},
    defaultPartitionExpirationMs: '',
    defaultRoundingMode: '',
    defaultTableExpirationMs: '',
    description: '',
    etag: '',
    friendlyName: '',
    id: '',
    isCaseInsensitive: false,
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    maxTimeTravelHours: '',
    satisfiesPzs: false,
    selfLink: '',
    storageBillingModel: '',
    tags: [{tagKey: '', tagValue: ''}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"access":[{"dataset":{"dataset":{"datasetId":"","projectId":""},"targetTypes":[]},"domain":"","groupByEmail":"","iamMember":"","role":"","routine":{"datasetId":"","projectId":"","routineId":""},"specialGroup":"","userByEmail":"","view":{"datasetId":"","projectId":"","tableId":""}}],"creationTime":"","datasetReference":{},"defaultCollation":"","defaultEncryptionConfiguration":{"kmsKeyName":""},"defaultPartitionExpirationMs":"","defaultRoundingMode":"","defaultTableExpirationMs":"","description":"","etag":"","friendlyName":"","id":"","isCaseInsensitive":false,"kind":"","labels":{},"lastModifiedTime":"","location":"","maxTimeTravelHours":"","satisfiesPzs":false,"selfLink":"","storageBillingModel":"","tags":[{"tagKey":"","tagValue":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId',
  method: 'PATCH',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "access": [\n    {\n      "dataset": {\n        "dataset": {\n          "datasetId": "",\n          "projectId": ""\n        },\n        "targetTypes": []\n      },\n      "domain": "",\n      "groupByEmail": "",\n      "iamMember": "",\n      "role": "",\n      "routine": {\n        "datasetId": "",\n        "projectId": "",\n        "routineId": ""\n      },\n      "specialGroup": "",\n      "userByEmail": "",\n      "view": {\n        "datasetId": "",\n        "projectId": "",\n        "tableId": ""\n      }\n    }\n  ],\n  "creationTime": "",\n  "datasetReference": {},\n  "defaultCollation": "",\n  "defaultEncryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "defaultPartitionExpirationMs": "",\n  "defaultRoundingMode": "",\n  "defaultTableExpirationMs": "",\n  "description": "",\n  "etag": "",\n  "friendlyName": "",\n  "id": "",\n  "isCaseInsensitive": false,\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "maxTimeTravelHours": "",\n  "satisfiesPzs": false,\n  "selfLink": "",\n  "storageBillingModel": "",\n  "tags": [\n    {\n      "tagKey": "",\n      "tagValue": ""\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  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId")
  .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/projects/:projectId/datasets/:datasetId',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  access: [
    {
      dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
      domain: '',
      groupByEmail: '',
      iamMember: '',
      role: '',
      routine: {datasetId: '', projectId: '', routineId: ''},
      specialGroup: '',
      userByEmail: '',
      view: {datasetId: '', projectId: '', tableId: ''}
    }
  ],
  creationTime: '',
  datasetReference: {},
  defaultCollation: '',
  defaultEncryptionConfiguration: {kmsKeyName: ''},
  defaultPartitionExpirationMs: '',
  defaultRoundingMode: '',
  defaultTableExpirationMs: '',
  description: '',
  etag: '',
  friendlyName: '',
  id: '',
  isCaseInsensitive: false,
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  maxTimeTravelHours: '',
  satisfiesPzs: false,
  selfLink: '',
  storageBillingModel: '',
  tags: [{tagKey: '', tagValue: ''}]
}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId',
  headers: {'content-type': 'application/json'},
  body: {
    access: [
      {
        dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
        domain: '',
        groupByEmail: '',
        iamMember: '',
        role: '',
        routine: {datasetId: '', projectId: '', routineId: ''},
        specialGroup: '',
        userByEmail: '',
        view: {datasetId: '', projectId: '', tableId: ''}
      }
    ],
    creationTime: '',
    datasetReference: {},
    defaultCollation: '',
    defaultEncryptionConfiguration: {kmsKeyName: ''},
    defaultPartitionExpirationMs: '',
    defaultRoundingMode: '',
    defaultTableExpirationMs: '',
    description: '',
    etag: '',
    friendlyName: '',
    id: '',
    isCaseInsensitive: false,
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    maxTimeTravelHours: '',
    satisfiesPzs: false,
    selfLink: '',
    storageBillingModel: '',
    tags: [{tagKey: '', tagValue: ''}]
  },
  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}}/projects/:projectId/datasets/:datasetId');

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

req.type('json');
req.send({
  access: [
    {
      dataset: {
        dataset: {
          datasetId: '',
          projectId: ''
        },
        targetTypes: []
      },
      domain: '',
      groupByEmail: '',
      iamMember: '',
      role: '',
      routine: {
        datasetId: '',
        projectId: '',
        routineId: ''
      },
      specialGroup: '',
      userByEmail: '',
      view: {
        datasetId: '',
        projectId: '',
        tableId: ''
      }
    }
  ],
  creationTime: '',
  datasetReference: {},
  defaultCollation: '',
  defaultEncryptionConfiguration: {
    kmsKeyName: ''
  },
  defaultPartitionExpirationMs: '',
  defaultRoundingMode: '',
  defaultTableExpirationMs: '',
  description: '',
  etag: '',
  friendlyName: '',
  id: '',
  isCaseInsensitive: false,
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  maxTimeTravelHours: '',
  satisfiesPzs: false,
  selfLink: '',
  storageBillingModel: '',
  tags: [
    {
      tagKey: '',
      tagValue: ''
    }
  ]
});

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}}/projects/:projectId/datasets/:datasetId',
  headers: {'content-type': 'application/json'},
  data: {
    access: [
      {
        dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
        domain: '',
        groupByEmail: '',
        iamMember: '',
        role: '',
        routine: {datasetId: '', projectId: '', routineId: ''},
        specialGroup: '',
        userByEmail: '',
        view: {datasetId: '', projectId: '', tableId: ''}
      }
    ],
    creationTime: '',
    datasetReference: {},
    defaultCollation: '',
    defaultEncryptionConfiguration: {kmsKeyName: ''},
    defaultPartitionExpirationMs: '',
    defaultRoundingMode: '',
    defaultTableExpirationMs: '',
    description: '',
    etag: '',
    friendlyName: '',
    id: '',
    isCaseInsensitive: false,
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    maxTimeTravelHours: '',
    satisfiesPzs: false,
    selfLink: '',
    storageBillingModel: '',
    tags: [{tagKey: '', tagValue: ''}]
  }
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"access":[{"dataset":{"dataset":{"datasetId":"","projectId":""},"targetTypes":[]},"domain":"","groupByEmail":"","iamMember":"","role":"","routine":{"datasetId":"","projectId":"","routineId":""},"specialGroup":"","userByEmail":"","view":{"datasetId":"","projectId":"","tableId":""}}],"creationTime":"","datasetReference":{},"defaultCollation":"","defaultEncryptionConfiguration":{"kmsKeyName":""},"defaultPartitionExpirationMs":"","defaultRoundingMode":"","defaultTableExpirationMs":"","description":"","etag":"","friendlyName":"","id":"","isCaseInsensitive":false,"kind":"","labels":{},"lastModifiedTime":"","location":"","maxTimeTravelHours":"","satisfiesPzs":false,"selfLink":"","storageBillingModel":"","tags":[{"tagKey":"","tagValue":""}]}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"access": @[ @{ @"dataset": @{ @"dataset": @{ @"datasetId": @"", @"projectId": @"" }, @"targetTypes": @[  ] }, @"domain": @"", @"groupByEmail": @"", @"iamMember": @"", @"role": @"", @"routine": @{ @"datasetId": @"", @"projectId": @"", @"routineId": @"" }, @"specialGroup": @"", @"userByEmail": @"", @"view": @{ @"datasetId": @"", @"projectId": @"", @"tableId": @"" } } ],
                              @"creationTime": @"",
                              @"datasetReference": @{  },
                              @"defaultCollation": @"",
                              @"defaultEncryptionConfiguration": @{ @"kmsKeyName": @"" },
                              @"defaultPartitionExpirationMs": @"",
                              @"defaultRoundingMode": @"",
                              @"defaultTableExpirationMs": @"",
                              @"description": @"",
                              @"etag": @"",
                              @"friendlyName": @"",
                              @"id": @"",
                              @"isCaseInsensitive": @NO,
                              @"kind": @"",
                              @"labels": @{  },
                              @"lastModifiedTime": @"",
                              @"location": @"",
                              @"maxTimeTravelHours": @"",
                              @"satisfiesPzs": @NO,
                              @"selfLink": @"",
                              @"storageBillingModel": @"",
                              @"tags": @[ @{ @"tagKey": @"", @"tagValue": @"" } ] };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/datasets/:datasetId"]
                                                       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}}/projects/:projectId/datasets/:datasetId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId",
  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([
    'access' => [
        [
                'dataset' => [
                                'dataset' => [
                                                                'datasetId' => '',
                                                                'projectId' => ''
                                ],
                                'targetTypes' => [
                                                                
                                ]
                ],
                'domain' => '',
                'groupByEmail' => '',
                'iamMember' => '',
                'role' => '',
                'routine' => [
                                'datasetId' => '',
                                'projectId' => '',
                                'routineId' => ''
                ],
                'specialGroup' => '',
                'userByEmail' => '',
                'view' => [
                                'datasetId' => '',
                                'projectId' => '',
                                'tableId' => ''
                ]
        ]
    ],
    'creationTime' => '',
    'datasetReference' => [
        
    ],
    'defaultCollation' => '',
    'defaultEncryptionConfiguration' => [
        'kmsKeyName' => ''
    ],
    'defaultPartitionExpirationMs' => '',
    'defaultRoundingMode' => '',
    'defaultTableExpirationMs' => '',
    'description' => '',
    'etag' => '',
    'friendlyName' => '',
    'id' => '',
    'isCaseInsensitive' => null,
    'kind' => '',
    'labels' => [
        
    ],
    'lastModifiedTime' => '',
    'location' => '',
    'maxTimeTravelHours' => '',
    'satisfiesPzs' => null,
    'selfLink' => '',
    'storageBillingModel' => '',
    'tags' => [
        [
                'tagKey' => '',
                'tagValue' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-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}}/projects/:projectId/datasets/:datasetId', [
  'body' => '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'access' => [
    [
        'dataset' => [
                'dataset' => [
                                'datasetId' => '',
                                'projectId' => ''
                ],
                'targetTypes' => [
                                
                ]
        ],
        'domain' => '',
        'groupByEmail' => '',
        'iamMember' => '',
        'role' => '',
        'routine' => [
                'datasetId' => '',
                'projectId' => '',
                'routineId' => ''
        ],
        'specialGroup' => '',
        'userByEmail' => '',
        'view' => [
                'datasetId' => '',
                'projectId' => '',
                'tableId' => ''
        ]
    ]
  ],
  'creationTime' => '',
  'datasetReference' => [
    
  ],
  'defaultCollation' => '',
  'defaultEncryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'defaultPartitionExpirationMs' => '',
  'defaultRoundingMode' => '',
  'defaultTableExpirationMs' => '',
  'description' => '',
  'etag' => '',
  'friendlyName' => '',
  'id' => '',
  'isCaseInsensitive' => null,
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'maxTimeTravelHours' => '',
  'satisfiesPzs' => null,
  'selfLink' => '',
  'storageBillingModel' => '',
  'tags' => [
    [
        'tagKey' => '',
        'tagValue' => ''
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'access' => [
    [
        'dataset' => [
                'dataset' => [
                                'datasetId' => '',
                                'projectId' => ''
                ],
                'targetTypes' => [
                                
                ]
        ],
        'domain' => '',
        'groupByEmail' => '',
        'iamMember' => '',
        'role' => '',
        'routine' => [
                'datasetId' => '',
                'projectId' => '',
                'routineId' => ''
        ],
        'specialGroup' => '',
        'userByEmail' => '',
        'view' => [
                'datasetId' => '',
                'projectId' => '',
                'tableId' => ''
        ]
    ]
  ],
  'creationTime' => '',
  'datasetReference' => [
    
  ],
  'defaultCollation' => '',
  'defaultEncryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'defaultPartitionExpirationMs' => '',
  'defaultRoundingMode' => '',
  'defaultTableExpirationMs' => '',
  'description' => '',
  'etag' => '',
  'friendlyName' => '',
  'id' => '',
  'isCaseInsensitive' => null,
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'maxTimeTravelHours' => '',
  'satisfiesPzs' => null,
  'selfLink' => '',
  'storageBillingModel' => '',
  'tags' => [
    [
        'tagKey' => '',
        'tagValue' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId');
$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}}/projects/:projectId/datasets/:datasetId' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}'
import http.client

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

payload = "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}"

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

conn.request("PATCH", "/baseUrl/projects/:projectId/datasets/:datasetId", payload, headers)

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

payload = {
    "access": [
        {
            "dataset": {
                "dataset": {
                    "datasetId": "",
                    "projectId": ""
                },
                "targetTypes": []
            },
            "domain": "",
            "groupByEmail": "",
            "iamMember": "",
            "role": "",
            "routine": {
                "datasetId": "",
                "projectId": "",
                "routineId": ""
            },
            "specialGroup": "",
            "userByEmail": "",
            "view": {
                "datasetId": "",
                "projectId": "",
                "tableId": ""
            }
        }
    ],
    "creationTime": "",
    "datasetReference": {},
    "defaultCollation": "",
    "defaultEncryptionConfiguration": { "kmsKeyName": "" },
    "defaultPartitionExpirationMs": "",
    "defaultRoundingMode": "",
    "defaultTableExpirationMs": "",
    "description": "",
    "etag": "",
    "friendlyName": "",
    "id": "",
    "isCaseInsensitive": False,
    "kind": "",
    "labels": {},
    "lastModifiedTime": "",
    "location": "",
    "maxTimeTravelHours": "",
    "satisfiesPzs": False,
    "selfLink": "",
    "storageBillingModel": "",
    "tags": [
        {
            "tagKey": "",
            "tagValue": ""
        }
    ]
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

payload <- "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\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}}/projects/:projectId/datasets/:datasetId")

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  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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.patch('/baseUrl/projects/:projectId/datasets/:datasetId') do |req|
  req.body = "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId";

    let payload = json!({
        "access": (
            json!({
                "dataset": json!({
                    "dataset": json!({
                        "datasetId": "",
                        "projectId": ""
                    }),
                    "targetTypes": ()
                }),
                "domain": "",
                "groupByEmail": "",
                "iamMember": "",
                "role": "",
                "routine": json!({
                    "datasetId": "",
                    "projectId": "",
                    "routineId": ""
                }),
                "specialGroup": "",
                "userByEmail": "",
                "view": json!({
                    "datasetId": "",
                    "projectId": "",
                    "tableId": ""
                })
            })
        ),
        "creationTime": "",
        "datasetReference": json!({}),
        "defaultCollation": "",
        "defaultEncryptionConfiguration": json!({"kmsKeyName": ""}),
        "defaultPartitionExpirationMs": "",
        "defaultRoundingMode": "",
        "defaultTableExpirationMs": "",
        "description": "",
        "etag": "",
        "friendlyName": "",
        "id": "",
        "isCaseInsensitive": false,
        "kind": "",
        "labels": json!({}),
        "lastModifiedTime": "",
        "location": "",
        "maxTimeTravelHours": "",
        "satisfiesPzs": false,
        "selfLink": "",
        "storageBillingModel": "",
        "tags": (
            json!({
                "tagKey": "",
                "tagValue": ""
            })
        )
    });

    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}}/projects/:projectId/datasets/:datasetId \
  --header 'content-type: application/json' \
  --data '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}'
echo '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}' |  \
  http PATCH {{baseUrl}}/projects/:projectId/datasets/:datasetId \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'content-type: application/json' \
  --body-data '{\n  "access": [\n    {\n      "dataset": {\n        "dataset": {\n          "datasetId": "",\n          "projectId": ""\n        },\n        "targetTypes": []\n      },\n      "domain": "",\n      "groupByEmail": "",\n      "iamMember": "",\n      "role": "",\n      "routine": {\n        "datasetId": "",\n        "projectId": "",\n        "routineId": ""\n      },\n      "specialGroup": "",\n      "userByEmail": "",\n      "view": {\n        "datasetId": "",\n        "projectId": "",\n        "tableId": ""\n      }\n    }\n  ],\n  "creationTime": "",\n  "datasetReference": {},\n  "defaultCollation": "",\n  "defaultEncryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "defaultPartitionExpirationMs": "",\n  "defaultRoundingMode": "",\n  "defaultTableExpirationMs": "",\n  "description": "",\n  "etag": "",\n  "friendlyName": "",\n  "id": "",\n  "isCaseInsensitive": false,\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "maxTimeTravelHours": "",\n  "satisfiesPzs": false,\n  "selfLink": "",\n  "storageBillingModel": "",\n  "tags": [\n    {\n      "tagKey": "",\n      "tagValue": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "access": [
    [
      "dataset": [
        "dataset": [
          "datasetId": "",
          "projectId": ""
        ],
        "targetTypes": []
      ],
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": [
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      ],
      "specialGroup": "",
      "userByEmail": "",
      "view": [
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      ]
    ]
  ],
  "creationTime": "",
  "datasetReference": [],
  "defaultCollation": "",
  "defaultEncryptionConfiguration": ["kmsKeyName": ""],
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": [],
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    [
      "tagKey": "",
      "tagValue": ""
    ]
  ]
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId")! 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()
PUT bigquery.datasets.update
{{baseUrl}}/projects/:projectId/datasets/:datasetId
QUERY PARAMS

projectId
datasetId
BODY json

{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}");

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

(client/put "{{baseUrl}}/projects/:projectId/datasets/:datasetId" {:content-type :json
                                                                                   :form-params {:access [{:dataset {:dataset {:datasetId ""
                                                                                                                               :projectId ""}
                                                                                                                     :targetTypes []}
                                                                                                           :domain ""
                                                                                                           :groupByEmail ""
                                                                                                           :iamMember ""
                                                                                                           :role ""
                                                                                                           :routine {:datasetId ""
                                                                                                                     :projectId ""
                                                                                                                     :routineId ""}
                                                                                                           :specialGroup ""
                                                                                                           :userByEmail ""
                                                                                                           :view {:datasetId ""
                                                                                                                  :projectId ""
                                                                                                                  :tableId ""}}]
                                                                                                 :creationTime ""
                                                                                                 :datasetReference {}
                                                                                                 :defaultCollation ""
                                                                                                 :defaultEncryptionConfiguration {:kmsKeyName ""}
                                                                                                 :defaultPartitionExpirationMs ""
                                                                                                 :defaultRoundingMode ""
                                                                                                 :defaultTableExpirationMs ""
                                                                                                 :description ""
                                                                                                 :etag ""
                                                                                                 :friendlyName ""
                                                                                                 :id ""
                                                                                                 :isCaseInsensitive false
                                                                                                 :kind ""
                                                                                                 :labels {}
                                                                                                 :lastModifiedTime ""
                                                                                                 :location ""
                                                                                                 :maxTimeTravelHours ""
                                                                                                 :satisfiesPzs false
                                                                                                 :selfLink ""
                                                                                                 :storageBillingModel ""
                                                                                                 :tags [{:tagKey ""
                                                                                                         :tagValue ""}]}})
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/projects/:projectId/datasets/:datasetId"),
    Content = new StringContent("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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}}/projects/:projectId/datasets/:datasetId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

	payload := strings.NewReader("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}")

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

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

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

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

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

}
PUT /baseUrl/projects/:projectId/datasets/:datasetId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1090

{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/projects/:projectId/datasets/:datasetId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\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  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/projects/:projectId/datasets/:datasetId")
  .header("content-type", "application/json")
  .body("{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  access: [
    {
      dataset: {
        dataset: {
          datasetId: '',
          projectId: ''
        },
        targetTypes: []
      },
      domain: '',
      groupByEmail: '',
      iamMember: '',
      role: '',
      routine: {
        datasetId: '',
        projectId: '',
        routineId: ''
      },
      specialGroup: '',
      userByEmail: '',
      view: {
        datasetId: '',
        projectId: '',
        tableId: ''
      }
    }
  ],
  creationTime: '',
  datasetReference: {},
  defaultCollation: '',
  defaultEncryptionConfiguration: {
    kmsKeyName: ''
  },
  defaultPartitionExpirationMs: '',
  defaultRoundingMode: '',
  defaultTableExpirationMs: '',
  description: '',
  etag: '',
  friendlyName: '',
  id: '',
  isCaseInsensitive: false,
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  maxTimeTravelHours: '',
  satisfiesPzs: false,
  selfLink: '',
  storageBillingModel: '',
  tags: [
    {
      tagKey: '',
      tagValue: ''
    }
  ]
});

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

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

xhr.open('PUT', '{{baseUrl}}/projects/:projectId/datasets/:datasetId');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId',
  headers: {'content-type': 'application/json'},
  data: {
    access: [
      {
        dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
        domain: '',
        groupByEmail: '',
        iamMember: '',
        role: '',
        routine: {datasetId: '', projectId: '', routineId: ''},
        specialGroup: '',
        userByEmail: '',
        view: {datasetId: '', projectId: '', tableId: ''}
      }
    ],
    creationTime: '',
    datasetReference: {},
    defaultCollation: '',
    defaultEncryptionConfiguration: {kmsKeyName: ''},
    defaultPartitionExpirationMs: '',
    defaultRoundingMode: '',
    defaultTableExpirationMs: '',
    description: '',
    etag: '',
    friendlyName: '',
    id: '',
    isCaseInsensitive: false,
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    maxTimeTravelHours: '',
    satisfiesPzs: false,
    selfLink: '',
    storageBillingModel: '',
    tags: [{tagKey: '', tagValue: ''}]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"access":[{"dataset":{"dataset":{"datasetId":"","projectId":""},"targetTypes":[]},"domain":"","groupByEmail":"","iamMember":"","role":"","routine":{"datasetId":"","projectId":"","routineId":""},"specialGroup":"","userByEmail":"","view":{"datasetId":"","projectId":"","tableId":""}}],"creationTime":"","datasetReference":{},"defaultCollation":"","defaultEncryptionConfiguration":{"kmsKeyName":""},"defaultPartitionExpirationMs":"","defaultRoundingMode":"","defaultTableExpirationMs":"","description":"","etag":"","friendlyName":"","id":"","isCaseInsensitive":false,"kind":"","labels":{},"lastModifiedTime":"","location":"","maxTimeTravelHours":"","satisfiesPzs":false,"selfLink":"","storageBillingModel":"","tags":[{"tagKey":"","tagValue":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "access": [\n    {\n      "dataset": {\n        "dataset": {\n          "datasetId": "",\n          "projectId": ""\n        },\n        "targetTypes": []\n      },\n      "domain": "",\n      "groupByEmail": "",\n      "iamMember": "",\n      "role": "",\n      "routine": {\n        "datasetId": "",\n        "projectId": "",\n        "routineId": ""\n      },\n      "specialGroup": "",\n      "userByEmail": "",\n      "view": {\n        "datasetId": "",\n        "projectId": "",\n        "tableId": ""\n      }\n    }\n  ],\n  "creationTime": "",\n  "datasetReference": {},\n  "defaultCollation": "",\n  "defaultEncryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "defaultPartitionExpirationMs": "",\n  "defaultRoundingMode": "",\n  "defaultTableExpirationMs": "",\n  "description": "",\n  "etag": "",\n  "friendlyName": "",\n  "id": "",\n  "isCaseInsensitive": false,\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "maxTimeTravelHours": "",\n  "satisfiesPzs": false,\n  "selfLink": "",\n  "storageBillingModel": "",\n  "tags": [\n    {\n      "tagKey": "",\n      "tagValue": ""\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  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  access: [
    {
      dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
      domain: '',
      groupByEmail: '',
      iamMember: '',
      role: '',
      routine: {datasetId: '', projectId: '', routineId: ''},
      specialGroup: '',
      userByEmail: '',
      view: {datasetId: '', projectId: '', tableId: ''}
    }
  ],
  creationTime: '',
  datasetReference: {},
  defaultCollation: '',
  defaultEncryptionConfiguration: {kmsKeyName: ''},
  defaultPartitionExpirationMs: '',
  defaultRoundingMode: '',
  defaultTableExpirationMs: '',
  description: '',
  etag: '',
  friendlyName: '',
  id: '',
  isCaseInsensitive: false,
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  maxTimeTravelHours: '',
  satisfiesPzs: false,
  selfLink: '',
  storageBillingModel: '',
  tags: [{tagKey: '', tagValue: ''}]
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId',
  headers: {'content-type': 'application/json'},
  body: {
    access: [
      {
        dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
        domain: '',
        groupByEmail: '',
        iamMember: '',
        role: '',
        routine: {datasetId: '', projectId: '', routineId: ''},
        specialGroup: '',
        userByEmail: '',
        view: {datasetId: '', projectId: '', tableId: ''}
      }
    ],
    creationTime: '',
    datasetReference: {},
    defaultCollation: '',
    defaultEncryptionConfiguration: {kmsKeyName: ''},
    defaultPartitionExpirationMs: '',
    defaultRoundingMode: '',
    defaultTableExpirationMs: '',
    description: '',
    etag: '',
    friendlyName: '',
    id: '',
    isCaseInsensitive: false,
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    maxTimeTravelHours: '',
    satisfiesPzs: false,
    selfLink: '',
    storageBillingModel: '',
    tags: [{tagKey: '', tagValue: ''}]
  },
  json: true
};

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

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

const req = unirest('PUT', '{{baseUrl}}/projects/:projectId/datasets/:datasetId');

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

req.type('json');
req.send({
  access: [
    {
      dataset: {
        dataset: {
          datasetId: '',
          projectId: ''
        },
        targetTypes: []
      },
      domain: '',
      groupByEmail: '',
      iamMember: '',
      role: '',
      routine: {
        datasetId: '',
        projectId: '',
        routineId: ''
      },
      specialGroup: '',
      userByEmail: '',
      view: {
        datasetId: '',
        projectId: '',
        tableId: ''
      }
    }
  ],
  creationTime: '',
  datasetReference: {},
  defaultCollation: '',
  defaultEncryptionConfiguration: {
    kmsKeyName: ''
  },
  defaultPartitionExpirationMs: '',
  defaultRoundingMode: '',
  defaultTableExpirationMs: '',
  description: '',
  etag: '',
  friendlyName: '',
  id: '',
  isCaseInsensitive: false,
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  maxTimeTravelHours: '',
  satisfiesPzs: false,
  selfLink: '',
  storageBillingModel: '',
  tags: [
    {
      tagKey: '',
      tagValue: ''
    }
  ]
});

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId',
  headers: {'content-type': 'application/json'},
  data: {
    access: [
      {
        dataset: {dataset: {datasetId: '', projectId: ''}, targetTypes: []},
        domain: '',
        groupByEmail: '',
        iamMember: '',
        role: '',
        routine: {datasetId: '', projectId: '', routineId: ''},
        specialGroup: '',
        userByEmail: '',
        view: {datasetId: '', projectId: '', tableId: ''}
      }
    ],
    creationTime: '',
    datasetReference: {},
    defaultCollation: '',
    defaultEncryptionConfiguration: {kmsKeyName: ''},
    defaultPartitionExpirationMs: '',
    defaultRoundingMode: '',
    defaultTableExpirationMs: '',
    description: '',
    etag: '',
    friendlyName: '',
    id: '',
    isCaseInsensitive: false,
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    maxTimeTravelHours: '',
    satisfiesPzs: false,
    selfLink: '',
    storageBillingModel: '',
    tags: [{tagKey: '', tagValue: ''}]
  }
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"access":[{"dataset":{"dataset":{"datasetId":"","projectId":""},"targetTypes":[]},"domain":"","groupByEmail":"","iamMember":"","role":"","routine":{"datasetId":"","projectId":"","routineId":""},"specialGroup":"","userByEmail":"","view":{"datasetId":"","projectId":"","tableId":""}}],"creationTime":"","datasetReference":{},"defaultCollation":"","defaultEncryptionConfiguration":{"kmsKeyName":""},"defaultPartitionExpirationMs":"","defaultRoundingMode":"","defaultTableExpirationMs":"","description":"","etag":"","friendlyName":"","id":"","isCaseInsensitive":false,"kind":"","labels":{},"lastModifiedTime":"","location":"","maxTimeTravelHours":"","satisfiesPzs":false,"selfLink":"","storageBillingModel":"","tags":[{"tagKey":"","tagValue":""}]}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"access": @[ @{ @"dataset": @{ @"dataset": @{ @"datasetId": @"", @"projectId": @"" }, @"targetTypes": @[  ] }, @"domain": @"", @"groupByEmail": @"", @"iamMember": @"", @"role": @"", @"routine": @{ @"datasetId": @"", @"projectId": @"", @"routineId": @"" }, @"specialGroup": @"", @"userByEmail": @"", @"view": @{ @"datasetId": @"", @"projectId": @"", @"tableId": @"" } } ],
                              @"creationTime": @"",
                              @"datasetReference": @{  },
                              @"defaultCollation": @"",
                              @"defaultEncryptionConfiguration": @{ @"kmsKeyName": @"" },
                              @"defaultPartitionExpirationMs": @"",
                              @"defaultRoundingMode": @"",
                              @"defaultTableExpirationMs": @"",
                              @"description": @"",
                              @"etag": @"",
                              @"friendlyName": @"",
                              @"id": @"",
                              @"isCaseInsensitive": @NO,
                              @"kind": @"",
                              @"labels": @{  },
                              @"lastModifiedTime": @"",
                              @"location": @"",
                              @"maxTimeTravelHours": @"",
                              @"satisfiesPzs": @NO,
                              @"selfLink": @"",
                              @"storageBillingModel": @"",
                              @"tags": @[ @{ @"tagKey": @"", @"tagValue": @"" } ] };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/datasets/:datasetId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/projects/:projectId/datasets/:datasetId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'access' => [
        [
                'dataset' => [
                                'dataset' => [
                                                                'datasetId' => '',
                                                                'projectId' => ''
                                ],
                                'targetTypes' => [
                                                                
                                ]
                ],
                'domain' => '',
                'groupByEmail' => '',
                'iamMember' => '',
                'role' => '',
                'routine' => [
                                'datasetId' => '',
                                'projectId' => '',
                                'routineId' => ''
                ],
                'specialGroup' => '',
                'userByEmail' => '',
                'view' => [
                                'datasetId' => '',
                                'projectId' => '',
                                'tableId' => ''
                ]
        ]
    ],
    'creationTime' => '',
    'datasetReference' => [
        
    ],
    'defaultCollation' => '',
    'defaultEncryptionConfiguration' => [
        'kmsKeyName' => ''
    ],
    'defaultPartitionExpirationMs' => '',
    'defaultRoundingMode' => '',
    'defaultTableExpirationMs' => '',
    'description' => '',
    'etag' => '',
    'friendlyName' => '',
    'id' => '',
    'isCaseInsensitive' => null,
    'kind' => '',
    'labels' => [
        
    ],
    'lastModifiedTime' => '',
    'location' => '',
    'maxTimeTravelHours' => '',
    'satisfiesPzs' => null,
    'selfLink' => '',
    'storageBillingModel' => '',
    'tags' => [
        [
                'tagKey' => '',
                'tagValue' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/projects/:projectId/datasets/:datasetId', [
  'body' => '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId');
$request->setMethod(HTTP_METH_PUT);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'access' => [
    [
        'dataset' => [
                'dataset' => [
                                'datasetId' => '',
                                'projectId' => ''
                ],
                'targetTypes' => [
                                
                ]
        ],
        'domain' => '',
        'groupByEmail' => '',
        'iamMember' => '',
        'role' => '',
        'routine' => [
                'datasetId' => '',
                'projectId' => '',
                'routineId' => ''
        ],
        'specialGroup' => '',
        'userByEmail' => '',
        'view' => [
                'datasetId' => '',
                'projectId' => '',
                'tableId' => ''
        ]
    ]
  ],
  'creationTime' => '',
  'datasetReference' => [
    
  ],
  'defaultCollation' => '',
  'defaultEncryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'defaultPartitionExpirationMs' => '',
  'defaultRoundingMode' => '',
  'defaultTableExpirationMs' => '',
  'description' => '',
  'etag' => '',
  'friendlyName' => '',
  'id' => '',
  'isCaseInsensitive' => null,
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'maxTimeTravelHours' => '',
  'satisfiesPzs' => null,
  'selfLink' => '',
  'storageBillingModel' => '',
  'tags' => [
    [
        'tagKey' => '',
        'tagValue' => ''
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'access' => [
    [
        'dataset' => [
                'dataset' => [
                                'datasetId' => '',
                                'projectId' => ''
                ],
                'targetTypes' => [
                                
                ]
        ],
        'domain' => '',
        'groupByEmail' => '',
        'iamMember' => '',
        'role' => '',
        'routine' => [
                'datasetId' => '',
                'projectId' => '',
                'routineId' => ''
        ],
        'specialGroup' => '',
        'userByEmail' => '',
        'view' => [
                'datasetId' => '',
                'projectId' => '',
                'tableId' => ''
        ]
    ]
  ],
  'creationTime' => '',
  'datasetReference' => [
    
  ],
  'defaultCollation' => '',
  'defaultEncryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'defaultPartitionExpirationMs' => '',
  'defaultRoundingMode' => '',
  'defaultTableExpirationMs' => '',
  'description' => '',
  'etag' => '',
  'friendlyName' => '',
  'id' => '',
  'isCaseInsensitive' => null,
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'maxTimeTravelHours' => '',
  'satisfiesPzs' => null,
  'selfLink' => '',
  'storageBillingModel' => '',
  'tags' => [
    [
        'tagKey' => '',
        'tagValue' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId');
$request->setRequestMethod('PUT');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}'
import http.client

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

payload = "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}"

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

conn.request("PUT", "/baseUrl/projects/:projectId/datasets/:datasetId", payload, headers)

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

payload = {
    "access": [
        {
            "dataset": {
                "dataset": {
                    "datasetId": "",
                    "projectId": ""
                },
                "targetTypes": []
            },
            "domain": "",
            "groupByEmail": "",
            "iamMember": "",
            "role": "",
            "routine": {
                "datasetId": "",
                "projectId": "",
                "routineId": ""
            },
            "specialGroup": "",
            "userByEmail": "",
            "view": {
                "datasetId": "",
                "projectId": "",
                "tableId": ""
            }
        }
    ],
    "creationTime": "",
    "datasetReference": {},
    "defaultCollation": "",
    "defaultEncryptionConfiguration": { "kmsKeyName": "" },
    "defaultPartitionExpirationMs": "",
    "defaultRoundingMode": "",
    "defaultTableExpirationMs": "",
    "description": "",
    "etag": "",
    "friendlyName": "",
    "id": "",
    "isCaseInsensitive": False,
    "kind": "",
    "labels": {},
    "lastModifiedTime": "",
    "location": "",
    "maxTimeTravelHours": "",
    "satisfiesPzs": False,
    "selfLink": "",
    "storageBillingModel": "",
    "tags": [
        {
            "tagKey": "",
            "tagValue": ""
        }
    ]
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId"

payload <- "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId")

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

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}"

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

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

response = conn.put('/baseUrl/projects/:projectId/datasets/:datasetId') do |req|
  req.body = "{\n  \"access\": [\n    {\n      \"dataset\": {\n        \"dataset\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\"\n        },\n        \"targetTypes\": []\n      },\n      \"domain\": \"\",\n      \"groupByEmail\": \"\",\n      \"iamMember\": \"\",\n      \"role\": \"\",\n      \"routine\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"routineId\": \"\"\n      },\n      \"specialGroup\": \"\",\n      \"userByEmail\": \"\",\n      \"view\": {\n        \"datasetId\": \"\",\n        \"projectId\": \"\",\n        \"tableId\": \"\"\n      }\n    }\n  ],\n  \"creationTime\": \"\",\n  \"datasetReference\": {},\n  \"defaultCollation\": \"\",\n  \"defaultEncryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"defaultPartitionExpirationMs\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"defaultTableExpirationMs\": \"\",\n  \"description\": \"\",\n  \"etag\": \"\",\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"isCaseInsensitive\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"maxTimeTravelHours\": \"\",\n  \"satisfiesPzs\": false,\n  \"selfLink\": \"\",\n  \"storageBillingModel\": \"\",\n  \"tags\": [\n    {\n      \"tagKey\": \"\",\n      \"tagValue\": \"\"\n    }\n  ]\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId";

    let payload = json!({
        "access": (
            json!({
                "dataset": json!({
                    "dataset": json!({
                        "datasetId": "",
                        "projectId": ""
                    }),
                    "targetTypes": ()
                }),
                "domain": "",
                "groupByEmail": "",
                "iamMember": "",
                "role": "",
                "routine": json!({
                    "datasetId": "",
                    "projectId": "",
                    "routineId": ""
                }),
                "specialGroup": "",
                "userByEmail": "",
                "view": json!({
                    "datasetId": "",
                    "projectId": "",
                    "tableId": ""
                })
            })
        ),
        "creationTime": "",
        "datasetReference": json!({}),
        "defaultCollation": "",
        "defaultEncryptionConfiguration": json!({"kmsKeyName": ""}),
        "defaultPartitionExpirationMs": "",
        "defaultRoundingMode": "",
        "defaultTableExpirationMs": "",
        "description": "",
        "etag": "",
        "friendlyName": "",
        "id": "",
        "isCaseInsensitive": false,
        "kind": "",
        "labels": json!({}),
        "lastModifiedTime": "",
        "location": "",
        "maxTimeTravelHours": "",
        "satisfiesPzs": false,
        "selfLink": "",
        "storageBillingModel": "",
        "tags": (
            json!({
                "tagKey": "",
                "tagValue": ""
            })
        )
    });

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/projects/:projectId/datasets/:datasetId \
  --header 'content-type: application/json' \
  --data '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}'
echo '{
  "access": [
    {
      "dataset": {
        "dataset": {
          "datasetId": "",
          "projectId": ""
        },
        "targetTypes": []
      },
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      },
      "specialGroup": "",
      "userByEmail": "",
      "view": {
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      }
    }
  ],
  "creationTime": "",
  "datasetReference": {},
  "defaultCollation": "",
  "defaultEncryptionConfiguration": {
    "kmsKeyName": ""
  },
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    {
      "tagKey": "",
      "tagValue": ""
    }
  ]
}' |  \
  http PUT {{baseUrl}}/projects/:projectId/datasets/:datasetId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "access": [\n    {\n      "dataset": {\n        "dataset": {\n          "datasetId": "",\n          "projectId": ""\n        },\n        "targetTypes": []\n      },\n      "domain": "",\n      "groupByEmail": "",\n      "iamMember": "",\n      "role": "",\n      "routine": {\n        "datasetId": "",\n        "projectId": "",\n        "routineId": ""\n      },\n      "specialGroup": "",\n      "userByEmail": "",\n      "view": {\n        "datasetId": "",\n        "projectId": "",\n        "tableId": ""\n      }\n    }\n  ],\n  "creationTime": "",\n  "datasetReference": {},\n  "defaultCollation": "",\n  "defaultEncryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "defaultPartitionExpirationMs": "",\n  "defaultRoundingMode": "",\n  "defaultTableExpirationMs": "",\n  "description": "",\n  "etag": "",\n  "friendlyName": "",\n  "id": "",\n  "isCaseInsensitive": false,\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "maxTimeTravelHours": "",\n  "satisfiesPzs": false,\n  "selfLink": "",\n  "storageBillingModel": "",\n  "tags": [\n    {\n      "tagKey": "",\n      "tagValue": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "access": [
    [
      "dataset": [
        "dataset": [
          "datasetId": "",
          "projectId": ""
        ],
        "targetTypes": []
      ],
      "domain": "",
      "groupByEmail": "",
      "iamMember": "",
      "role": "",
      "routine": [
        "datasetId": "",
        "projectId": "",
        "routineId": ""
      ],
      "specialGroup": "",
      "userByEmail": "",
      "view": [
        "datasetId": "",
        "projectId": "",
        "tableId": ""
      ]
    ]
  ],
  "creationTime": "",
  "datasetReference": [],
  "defaultCollation": "",
  "defaultEncryptionConfiguration": ["kmsKeyName": ""],
  "defaultPartitionExpirationMs": "",
  "defaultRoundingMode": "",
  "defaultTableExpirationMs": "",
  "description": "",
  "etag": "",
  "friendlyName": "",
  "id": "",
  "isCaseInsensitive": false,
  "kind": "",
  "labels": [],
  "lastModifiedTime": "",
  "location": "",
  "maxTimeTravelHours": "",
  "satisfiesPzs": false,
  "selfLink": "",
  "storageBillingModel": "",
  "tags": [
    [
      "tagKey": "",
      "tagValue": ""
    ]
  ]
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
POST bigquery.jobs.cancel
{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel
QUERY PARAMS

projectId
jobId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel");

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

(client/post "{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel"

response = HTTP::Client.post url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel");
var request = new RestRequest("", Method.Post);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel"

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

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

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

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

}
POST /baseUrl/projects/:projectId/jobs/:jobId/cancel HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel")
  .asString();
const data = null;

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

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

xhr.open('POST', '{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel',
  method: 'POST',
  headers: {}
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel")
  .post(null)
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/jobs/:jobId/cancel',
  headers: {}
};

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel'
};

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

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

const req = unirest('POST', '{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel');

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel'
};

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

const url = '{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel';
const options = {method: 'POST'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

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

let uri = Uri.of_string "{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel" in

Client.call `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel');

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel');
$request->setMethod(HTTP_METH_POST);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel');
$request->setRequestMethod('POST');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel' -Method POST 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel' -Method POST 
import http.client

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

conn.request("POST", "/baseUrl/projects/:projectId/jobs/:jobId/cancel")

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

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

url = "{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel"

response = requests.post(url)

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

url <- "{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel"

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

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

url = URI("{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel")

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

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

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

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

response = conn.post('/baseUrl/projects/:projectId/jobs/:jobId/cancel') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel";

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/projects/:projectId/jobs/:jobId/cancel
http POST {{baseUrl}}/projects/:projectId/jobs/:jobId/cancel
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/projects/:projectId/jobs/:jobId/cancel
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/jobs/:jobId/cancel")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

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

dataTask.resume()
DELETE bigquery.jobs.delete
{{baseUrl}}/projects/:projectId/jobs/:jobId/delete
QUERY PARAMS

projectId
jobId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/jobs/:jobId/delete");

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

(client/delete "{{baseUrl}}/projects/:projectId/jobs/:jobId/delete")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/jobs/:jobId/delete"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/jobs/:jobId/delete"

	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/projects/:projectId/jobs/:jobId/delete HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/projects/:projectId/jobs/:jobId/delete")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

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

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/projects/:projectId/jobs/:jobId/delete'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/jobs/:jobId/delete")
  .delete(null)
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/jobs/:jobId/delete',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/jobs/:jobId/delete'
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/projects/:projectId/jobs/:jobId/delete');

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}}/projects/:projectId/jobs/:jobId/delete'
};

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

const url = '{{baseUrl}}/projects/:projectId/jobs/:jobId/delete';
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}}/projects/:projectId/jobs/:jobId/delete"]
                                                       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}}/projects/:projectId/jobs/:jobId/delete" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/jobs/:jobId/delete');
$request->setMethod(HTTP_METH_DELETE);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/jobs/:jobId/delete');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/jobs/:jobId/delete' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/jobs/:jobId/delete' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/projects/:projectId/jobs/:jobId/delete")

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

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

url = "{{baseUrl}}/projects/:projectId/jobs/:jobId/delete"

response = requests.delete(url)

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

url <- "{{baseUrl}}/projects/:projectId/jobs/:jobId/delete"

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

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

url = URI("{{baseUrl}}/projects/:projectId/jobs/:jobId/delete")

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/projects/:projectId/jobs/:jobId/delete') do |req|
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/jobs/:jobId/delete";

    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}}/projects/:projectId/jobs/:jobId/delete
http DELETE {{baseUrl}}/projects/:projectId/jobs/:jobId/delete
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/projects/:projectId/jobs/:jobId/delete
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/jobs/:jobId/delete")! 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 bigquery.jobs.get
{{baseUrl}}/projects/:projectId/jobs/:jobId
QUERY PARAMS

projectId
jobId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/jobs/:jobId");

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

(client/get "{{baseUrl}}/projects/:projectId/jobs/:jobId")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/jobs/:jobId"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/jobs/:jobId"

	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/projects/:projectId/jobs/:jobId HTTP/1.1
Host: example.com

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/jobs/:jobId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/jobs/:jobId")
  .get()
  .build()

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

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

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/jobs/:jobId'
};

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

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

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/jobs/:jobId');

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}}/projects/:projectId/jobs/:jobId'
};

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/projects/:projectId/jobs/:jobId")

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

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

url = "{{baseUrl}}/projects/:projectId/jobs/:jobId"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/jobs/:jobId"

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

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

url = URI("{{baseUrl}}/projects/:projectId/jobs/:jobId")

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/projects/:projectId/jobs/:jobId') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/jobs/:jobId")! 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 bigquery.jobs.getQueryResults
{{baseUrl}}/projects/:projectId/queries/:jobId
QUERY PARAMS

projectId
jobId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/queries/:jobId");

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

(client/get "{{baseUrl}}/projects/:projectId/queries/:jobId")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/queries/:jobId"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/queries/:jobId"

	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/projects/:projectId/queries/:jobId HTTP/1.1
Host: example.com

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:projectId/queries/:jobId")
  .asString();
const 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}}/projects/:projectId/queries/:jobId');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/queries/:jobId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/queries/:jobId")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/queries/:jobId',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/queries/:jobId'
};

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

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

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/queries/:jobId');

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}}/projects/:projectId/queries/:jobId'
};

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

const url = '{{baseUrl}}/projects/:projectId/queries/:jobId';
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}}/projects/:projectId/queries/:jobId"]
                                                       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}}/projects/:projectId/queries/:jobId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/queries/:jobId');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/projects/:projectId/queries/:jobId")

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

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

url = "{{baseUrl}}/projects/:projectId/queries/:jobId"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/queries/:jobId"

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

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

url = URI("{{baseUrl}}/projects/:projectId/queries/:jobId")

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/projects/:projectId/queries/:jobId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/queries/:jobId";

    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}}/projects/:projectId/queries/:jobId
http GET {{baseUrl}}/projects/:projectId/queries/:jobId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/projects/:projectId/queries/:jobId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/queries/:jobId")! 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 bigquery.jobs.insert
{{baseUrl}}/projects/:projectId/jobs
QUERY PARAMS

projectId
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/post "{{baseUrl}}/projects/:projectId/jobs")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/jobs"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/jobs"

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

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

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

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

}
POST /baseUrl/projects/:projectId/jobs HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/jobs")
  .post(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/projects/:projectId/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('POST', '{{baseUrl}}/projects/:projectId/jobs');

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

const options = {method: 'POST', url: '{{baseUrl}}/projects/:projectId/jobs'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/jobs';
const options = {method: 'POST'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/projects/:projectId/jobs',
  method: 'POST',
  headers: {}
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/jobs")
  .post(null)
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/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: 'POST', url: '{{baseUrl}}/projects/:projectId/jobs'};

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

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

const req = unirest('POST', '{{baseUrl}}/projects/:projectId/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: 'POST', url: '{{baseUrl}}/projects/:projectId/jobs'};

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

const url = '{{baseUrl}}/projects/:projectId/jobs';
const options = {method: 'POST'};

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/jobs"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];

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

let uri = Uri.of_string "{{baseUrl}}/projects/:projectId/jobs" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/projects/:projectId/jobs');

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

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

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

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

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

conn.request("POST", "/baseUrl/projects/:projectId/jobs")

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

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

url = "{{baseUrl}}/projects/:projectId/jobs"

response = requests.post(url)

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

url <- "{{baseUrl}}/projects/:projectId/jobs"

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

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

url = URI("{{baseUrl}}/projects/:projectId/jobs")

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

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

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

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

response = conn.post('/baseUrl/projects/:projectId/jobs') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/projects/:projectId/jobs
http POST {{baseUrl}}/projects/:projectId/jobs
wget --quiet \
  --method POST \
  --output-document \
  - {{baseUrl}}/projects/:projectId/jobs
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/jobs")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"

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

dataTask.resume()
GET bigquery.jobs.list
{{baseUrl}}/projects/:projectId/jobs
QUERY PARAMS

projectId
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/projects/:projectId/jobs")
require "http/client"

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

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

func main() {

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/projects/:projectId/jobs'};

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

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

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

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

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

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

const url = '{{baseUrl}}/projects/:projectId/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}}/projects/:projectId/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}}/projects/:projectId/jobs" in

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

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

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

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

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

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

conn.request("GET", "/baseUrl/projects/:projectId/jobs")

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

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

url = "{{baseUrl}}/projects/:projectId/jobs"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/jobs"

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

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

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

puts response.status
puts response.body
use reqwest;

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/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()
POST bigquery.jobs.query
{{baseUrl}}/projects/:projectId/queries
QUERY PARAMS

projectId
BODY json

{
  "connectionProperties": [
    {
      "key": "",
      "value": ""
    }
  ],
  "continuous": false,
  "createSession": false,
  "defaultDataset": {
    "datasetId": "",
    "projectId": ""
  },
  "dryRun": false,
  "kind": "",
  "labels": {},
  "location": "",
  "maxResults": 0,
  "maximumBytesBilled": "",
  "parameterMode": "",
  "preserveNulls": false,
  "query": "",
  "queryParameters": [
    {
      "name": "",
      "parameterType": {
        "arrayType": "",
        "structTypes": [
          {
            "description": "",
            "name": "",
            "type": ""
          }
        ],
        "type": ""
      },
      "parameterValue": {
        "arrayValues": [],
        "structValues": {},
        "value": ""
      }
    }
  ],
  "requestId": "",
  "timeoutMs": 0,
  "useLegacySql": false,
  "useQueryCache": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/queries");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": false\n}");

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

(client/post "{{baseUrl}}/projects/:projectId/queries" {:content-type :json
                                                                        :form-params {:connectionProperties [{:key ""
                                                                                                              :value ""}]
                                                                                      :continuous false
                                                                                      :createSession false
                                                                                      :defaultDataset {:datasetId ""
                                                                                                       :projectId ""}
                                                                                      :dryRun false
                                                                                      :kind ""
                                                                                      :labels {}
                                                                                      :location ""
                                                                                      :maxResults 0
                                                                                      :maximumBytesBilled ""
                                                                                      :parameterMode ""
                                                                                      :preserveNulls false
                                                                                      :query ""
                                                                                      :queryParameters [{:name ""
                                                                                                         :parameterType {:arrayType ""
                                                                                                                         :structTypes [{:description ""
                                                                                                                                        :name ""
                                                                                                                                        :type ""}]
                                                                                                                         :type ""}
                                                                                                         :parameterValue {:arrayValues []
                                                                                                                          :structValues {}
                                                                                                                          :value ""}}]
                                                                                      :requestId ""
                                                                                      :timeoutMs 0
                                                                                      :useLegacySql false
                                                                                      :useQueryCache false}})
require "http/client"

url = "{{baseUrl}}/projects/:projectId/queries"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": 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}}/projects/:projectId/queries"),
    Content = new StringContent("{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": 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}}/projects/:projectId/queries");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/queries"

	payload := strings.NewReader("{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": 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/projects/:projectId/queries HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 848

{
  "connectionProperties": [
    {
      "key": "",
      "value": ""
    }
  ],
  "continuous": false,
  "createSession": false,
  "defaultDataset": {
    "datasetId": "",
    "projectId": ""
  },
  "dryRun": false,
  "kind": "",
  "labels": {},
  "location": "",
  "maxResults": 0,
  "maximumBytesBilled": "",
  "parameterMode": "",
  "preserveNulls": false,
  "query": "",
  "queryParameters": [
    {
      "name": "",
      "parameterType": {
        "arrayType": "",
        "structTypes": [
          {
            "description": "",
            "name": "",
            "type": ""
          }
        ],
        "type": ""
      },
      "parameterValue": {
        "arrayValues": [],
        "structValues": {},
        "value": ""
      }
    }
  ],
  "requestId": "",
  "timeoutMs": 0,
  "useLegacySql": false,
  "useQueryCache": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/projects/:projectId/queries")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/queries"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": 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  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/queries")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/projects/:projectId/queries")
  .header("content-type", "application/json")
  .body("{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": false\n}")
  .asString();
const data = JSON.stringify({
  connectionProperties: [
    {
      key: '',
      value: ''
    }
  ],
  continuous: false,
  createSession: false,
  defaultDataset: {
    datasetId: '',
    projectId: ''
  },
  dryRun: false,
  kind: '',
  labels: {},
  location: '',
  maxResults: 0,
  maximumBytesBilled: '',
  parameterMode: '',
  preserveNulls: false,
  query: '',
  queryParameters: [
    {
      name: '',
      parameterType: {
        arrayType: '',
        structTypes: [
          {
            description: '',
            name: '',
            type: ''
          }
        ],
        type: ''
      },
      parameterValue: {
        arrayValues: [],
        structValues: {},
        value: ''
      }
    }
  ],
  requestId: '',
  timeoutMs: 0,
  useLegacySql: false,
  useQueryCache: 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}}/projects/:projectId/queries');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/queries',
  headers: {'content-type': 'application/json'},
  data: {
    connectionProperties: [{key: '', value: ''}],
    continuous: false,
    createSession: false,
    defaultDataset: {datasetId: '', projectId: ''},
    dryRun: false,
    kind: '',
    labels: {},
    location: '',
    maxResults: 0,
    maximumBytesBilled: '',
    parameterMode: '',
    preserveNulls: false,
    query: '',
    queryParameters: [
      {
        name: '',
        parameterType: {arrayType: '', structTypes: [{description: '', name: '', type: ''}], type: ''},
        parameterValue: {arrayValues: [], structValues: {}, value: ''}
      }
    ],
    requestId: '',
    timeoutMs: 0,
    useLegacySql: false,
    useQueryCache: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/queries';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"connectionProperties":[{"key":"","value":""}],"continuous":false,"createSession":false,"defaultDataset":{"datasetId":"","projectId":""},"dryRun":false,"kind":"","labels":{},"location":"","maxResults":0,"maximumBytesBilled":"","parameterMode":"","preserveNulls":false,"query":"","queryParameters":[{"name":"","parameterType":{"arrayType":"","structTypes":[{"description":"","name":"","type":""}],"type":""},"parameterValue":{"arrayValues":[],"structValues":{},"value":""}}],"requestId":"","timeoutMs":0,"useLegacySql":false,"useQueryCache":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}}/projects/:projectId/queries',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "connectionProperties": [\n    {\n      "key": "",\n      "value": ""\n    }\n  ],\n  "continuous": false,\n  "createSession": false,\n  "defaultDataset": {\n    "datasetId": "",\n    "projectId": ""\n  },\n  "dryRun": false,\n  "kind": "",\n  "labels": {},\n  "location": "",\n  "maxResults": 0,\n  "maximumBytesBilled": "",\n  "parameterMode": "",\n  "preserveNulls": false,\n  "query": "",\n  "queryParameters": [\n    {\n      "name": "",\n      "parameterType": {\n        "arrayType": "",\n        "structTypes": [\n          {\n            "description": "",\n            "name": "",\n            "type": ""\n          }\n        ],\n        "type": ""\n      },\n      "parameterValue": {\n        "arrayValues": [],\n        "structValues": {},\n        "value": ""\n      }\n    }\n  ],\n  "requestId": "",\n  "timeoutMs": 0,\n  "useLegacySql": false,\n  "useQueryCache": 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  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/queries")
  .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/projects/:projectId/queries',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  connectionProperties: [{key: '', value: ''}],
  continuous: false,
  createSession: false,
  defaultDataset: {datasetId: '', projectId: ''},
  dryRun: false,
  kind: '',
  labels: {},
  location: '',
  maxResults: 0,
  maximumBytesBilled: '',
  parameterMode: '',
  preserveNulls: false,
  query: '',
  queryParameters: [
    {
      name: '',
      parameterType: {arrayType: '', structTypes: [{description: '', name: '', type: ''}], type: ''},
      parameterValue: {arrayValues: [], structValues: {}, value: ''}
    }
  ],
  requestId: '',
  timeoutMs: 0,
  useLegacySql: false,
  useQueryCache: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/queries',
  headers: {'content-type': 'application/json'},
  body: {
    connectionProperties: [{key: '', value: ''}],
    continuous: false,
    createSession: false,
    defaultDataset: {datasetId: '', projectId: ''},
    dryRun: false,
    kind: '',
    labels: {},
    location: '',
    maxResults: 0,
    maximumBytesBilled: '',
    parameterMode: '',
    preserveNulls: false,
    query: '',
    queryParameters: [
      {
        name: '',
        parameterType: {arrayType: '', structTypes: [{description: '', name: '', type: ''}], type: ''},
        parameterValue: {arrayValues: [], structValues: {}, value: ''}
      }
    ],
    requestId: '',
    timeoutMs: 0,
    useLegacySql: false,
    useQueryCache: 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}}/projects/:projectId/queries');

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

req.type('json');
req.send({
  connectionProperties: [
    {
      key: '',
      value: ''
    }
  ],
  continuous: false,
  createSession: false,
  defaultDataset: {
    datasetId: '',
    projectId: ''
  },
  dryRun: false,
  kind: '',
  labels: {},
  location: '',
  maxResults: 0,
  maximumBytesBilled: '',
  parameterMode: '',
  preserveNulls: false,
  query: '',
  queryParameters: [
    {
      name: '',
      parameterType: {
        arrayType: '',
        structTypes: [
          {
            description: '',
            name: '',
            type: ''
          }
        ],
        type: ''
      },
      parameterValue: {
        arrayValues: [],
        structValues: {},
        value: ''
      }
    }
  ],
  requestId: '',
  timeoutMs: 0,
  useLegacySql: false,
  useQueryCache: 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}}/projects/:projectId/queries',
  headers: {'content-type': 'application/json'},
  data: {
    connectionProperties: [{key: '', value: ''}],
    continuous: false,
    createSession: false,
    defaultDataset: {datasetId: '', projectId: ''},
    dryRun: false,
    kind: '',
    labels: {},
    location: '',
    maxResults: 0,
    maximumBytesBilled: '',
    parameterMode: '',
    preserveNulls: false,
    query: '',
    queryParameters: [
      {
        name: '',
        parameterType: {arrayType: '', structTypes: [{description: '', name: '', type: ''}], type: ''},
        parameterValue: {arrayValues: [], structValues: {}, value: ''}
      }
    ],
    requestId: '',
    timeoutMs: 0,
    useLegacySql: false,
    useQueryCache: false
  }
};

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

const url = '{{baseUrl}}/projects/:projectId/queries';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"connectionProperties":[{"key":"","value":""}],"continuous":false,"createSession":false,"defaultDataset":{"datasetId":"","projectId":""},"dryRun":false,"kind":"","labels":{},"location":"","maxResults":0,"maximumBytesBilled":"","parameterMode":"","preserveNulls":false,"query":"","queryParameters":[{"name":"","parameterType":{"arrayType":"","structTypes":[{"description":"","name":"","type":""}],"type":""},"parameterValue":{"arrayValues":[],"structValues":{},"value":""}}],"requestId":"","timeoutMs":0,"useLegacySql":false,"useQueryCache":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 = @{ @"connectionProperties": @[ @{ @"key": @"", @"value": @"" } ],
                              @"continuous": @NO,
                              @"createSession": @NO,
                              @"defaultDataset": @{ @"datasetId": @"", @"projectId": @"" },
                              @"dryRun": @NO,
                              @"kind": @"",
                              @"labels": @{  },
                              @"location": @"",
                              @"maxResults": @0,
                              @"maximumBytesBilled": @"",
                              @"parameterMode": @"",
                              @"preserveNulls": @NO,
                              @"query": @"",
                              @"queryParameters": @[ @{ @"name": @"", @"parameterType": @{ @"arrayType": @"", @"structTypes": @[ @{ @"description": @"", @"name": @"", @"type": @"" } ], @"type": @"" }, @"parameterValue": @{ @"arrayValues": @[  ], @"structValues": @{  }, @"value": @"" } } ],
                              @"requestId": @"",
                              @"timeoutMs": @0,
                              @"useLegacySql": @NO,
                              @"useQueryCache": @NO };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/queries"]
                                                       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}}/projects/:projectId/queries" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/queries",
  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([
    'connectionProperties' => [
        [
                'key' => '',
                'value' => ''
        ]
    ],
    'continuous' => null,
    'createSession' => null,
    'defaultDataset' => [
        'datasetId' => '',
        'projectId' => ''
    ],
    'dryRun' => null,
    'kind' => '',
    'labels' => [
        
    ],
    'location' => '',
    'maxResults' => 0,
    'maximumBytesBilled' => '',
    'parameterMode' => '',
    'preserveNulls' => null,
    'query' => '',
    'queryParameters' => [
        [
                'name' => '',
                'parameterType' => [
                                'arrayType' => '',
                                'structTypes' => [
                                                                [
                                                                                                                                'description' => '',
                                                                                                                                'name' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'type' => ''
                ],
                'parameterValue' => [
                                'arrayValues' => [
                                                                
                                ],
                                'structValues' => [
                                                                
                                ],
                                'value' => ''
                ]
        ]
    ],
    'requestId' => '',
    'timeoutMs' => 0,
    'useLegacySql' => null,
    'useQueryCache' => 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}}/projects/:projectId/queries', [
  'body' => '{
  "connectionProperties": [
    {
      "key": "",
      "value": ""
    }
  ],
  "continuous": false,
  "createSession": false,
  "defaultDataset": {
    "datasetId": "",
    "projectId": ""
  },
  "dryRun": false,
  "kind": "",
  "labels": {},
  "location": "",
  "maxResults": 0,
  "maximumBytesBilled": "",
  "parameterMode": "",
  "preserveNulls": false,
  "query": "",
  "queryParameters": [
    {
      "name": "",
      "parameterType": {
        "arrayType": "",
        "structTypes": [
          {
            "description": "",
            "name": "",
            "type": ""
          }
        ],
        "type": ""
      },
      "parameterValue": {
        "arrayValues": [],
        "structValues": {},
        "value": ""
      }
    }
  ],
  "requestId": "",
  "timeoutMs": 0,
  "useLegacySql": false,
  "useQueryCache": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/queries');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'connectionProperties' => [
    [
        'key' => '',
        'value' => ''
    ]
  ],
  'continuous' => null,
  'createSession' => null,
  'defaultDataset' => [
    'datasetId' => '',
    'projectId' => ''
  ],
  'dryRun' => null,
  'kind' => '',
  'labels' => [
    
  ],
  'location' => '',
  'maxResults' => 0,
  'maximumBytesBilled' => '',
  'parameterMode' => '',
  'preserveNulls' => null,
  'query' => '',
  'queryParameters' => [
    [
        'name' => '',
        'parameterType' => [
                'arrayType' => '',
                'structTypes' => [
                                [
                                                                'description' => '',
                                                                'name' => '',
                                                                'type' => ''
                                ]
                ],
                'type' => ''
        ],
        'parameterValue' => [
                'arrayValues' => [
                                
                ],
                'structValues' => [
                                
                ],
                'value' => ''
        ]
    ]
  ],
  'requestId' => '',
  'timeoutMs' => 0,
  'useLegacySql' => null,
  'useQueryCache' => null
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'connectionProperties' => [
    [
        'key' => '',
        'value' => ''
    ]
  ],
  'continuous' => null,
  'createSession' => null,
  'defaultDataset' => [
    'datasetId' => '',
    'projectId' => ''
  ],
  'dryRun' => null,
  'kind' => '',
  'labels' => [
    
  ],
  'location' => '',
  'maxResults' => 0,
  'maximumBytesBilled' => '',
  'parameterMode' => '',
  'preserveNulls' => null,
  'query' => '',
  'queryParameters' => [
    [
        'name' => '',
        'parameterType' => [
                'arrayType' => '',
                'structTypes' => [
                                [
                                                                'description' => '',
                                                                'name' => '',
                                                                'type' => ''
                                ]
                ],
                'type' => ''
        ],
        'parameterValue' => [
                'arrayValues' => [
                                
                ],
                'structValues' => [
                                
                ],
                'value' => ''
        ]
    ]
  ],
  'requestId' => '',
  'timeoutMs' => 0,
  'useLegacySql' => null,
  'useQueryCache' => null
]));
$request->setRequestUrl('{{baseUrl}}/projects/:projectId/queries');
$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}}/projects/:projectId/queries' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "connectionProperties": [
    {
      "key": "",
      "value": ""
    }
  ],
  "continuous": false,
  "createSession": false,
  "defaultDataset": {
    "datasetId": "",
    "projectId": ""
  },
  "dryRun": false,
  "kind": "",
  "labels": {},
  "location": "",
  "maxResults": 0,
  "maximumBytesBilled": "",
  "parameterMode": "",
  "preserveNulls": false,
  "query": "",
  "queryParameters": [
    {
      "name": "",
      "parameterType": {
        "arrayType": "",
        "structTypes": [
          {
            "description": "",
            "name": "",
            "type": ""
          }
        ],
        "type": ""
      },
      "parameterValue": {
        "arrayValues": [],
        "structValues": {},
        "value": ""
      }
    }
  ],
  "requestId": "",
  "timeoutMs": 0,
  "useLegacySql": false,
  "useQueryCache": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/queries' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "connectionProperties": [
    {
      "key": "",
      "value": ""
    }
  ],
  "continuous": false,
  "createSession": false,
  "defaultDataset": {
    "datasetId": "",
    "projectId": ""
  },
  "dryRun": false,
  "kind": "",
  "labels": {},
  "location": "",
  "maxResults": 0,
  "maximumBytesBilled": "",
  "parameterMode": "",
  "preserveNulls": false,
  "query": "",
  "queryParameters": [
    {
      "name": "",
      "parameterType": {
        "arrayType": "",
        "structTypes": [
          {
            "description": "",
            "name": "",
            "type": ""
          }
        ],
        "type": ""
      },
      "parameterValue": {
        "arrayValues": [],
        "structValues": {},
        "value": ""
      }
    }
  ],
  "requestId": "",
  "timeoutMs": 0,
  "useLegacySql": false,
  "useQueryCache": false
}'
import http.client

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

payload = "{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": false\n}"

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

conn.request("POST", "/baseUrl/projects/:projectId/queries", payload, headers)

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

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

url = "{{baseUrl}}/projects/:projectId/queries"

payload = {
    "connectionProperties": [
        {
            "key": "",
            "value": ""
        }
    ],
    "continuous": False,
    "createSession": False,
    "defaultDataset": {
        "datasetId": "",
        "projectId": ""
    },
    "dryRun": False,
    "kind": "",
    "labels": {},
    "location": "",
    "maxResults": 0,
    "maximumBytesBilled": "",
    "parameterMode": "",
    "preserveNulls": False,
    "query": "",
    "queryParameters": [
        {
            "name": "",
            "parameterType": {
                "arrayType": "",
                "structTypes": [
                    {
                        "description": "",
                        "name": "",
                        "type": ""
                    }
                ],
                "type": ""
            },
            "parameterValue": {
                "arrayValues": [],
                "structValues": {},
                "value": ""
            }
        }
    ],
    "requestId": "",
    "timeoutMs": 0,
    "useLegacySql": False,
    "useQueryCache": False
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/projects/:projectId/queries"

payload <- "{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": 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}}/projects/:projectId/queries")

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  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": 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/projects/:projectId/queries') do |req|
  req.body = "{\n  \"connectionProperties\": [\n    {\n      \"key\": \"\",\n      \"value\": \"\"\n    }\n  ],\n  \"continuous\": false,\n  \"createSession\": false,\n  \"defaultDataset\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"dryRun\": false,\n  \"kind\": \"\",\n  \"labels\": {},\n  \"location\": \"\",\n  \"maxResults\": 0,\n  \"maximumBytesBilled\": \"\",\n  \"parameterMode\": \"\",\n  \"preserveNulls\": false,\n  \"query\": \"\",\n  \"queryParameters\": [\n    {\n      \"name\": \"\",\n      \"parameterType\": {\n        \"arrayType\": \"\",\n        \"structTypes\": [\n          {\n            \"description\": \"\",\n            \"name\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"type\": \"\"\n      },\n      \"parameterValue\": {\n        \"arrayValues\": [],\n        \"structValues\": {},\n        \"value\": \"\"\n      }\n    }\n  ],\n  \"requestId\": \"\",\n  \"timeoutMs\": 0,\n  \"useLegacySql\": false,\n  \"useQueryCache\": false\n}"
end

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

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

    let payload = json!({
        "connectionProperties": (
            json!({
                "key": "",
                "value": ""
            })
        ),
        "continuous": false,
        "createSession": false,
        "defaultDataset": json!({
            "datasetId": "",
            "projectId": ""
        }),
        "dryRun": false,
        "kind": "",
        "labels": json!({}),
        "location": "",
        "maxResults": 0,
        "maximumBytesBilled": "",
        "parameterMode": "",
        "preserveNulls": false,
        "query": "",
        "queryParameters": (
            json!({
                "name": "",
                "parameterType": json!({
                    "arrayType": "",
                    "structTypes": (
                        json!({
                            "description": "",
                            "name": "",
                            "type": ""
                        })
                    ),
                    "type": ""
                }),
                "parameterValue": json!({
                    "arrayValues": (),
                    "structValues": json!({}),
                    "value": ""
                })
            })
        ),
        "requestId": "",
        "timeoutMs": 0,
        "useLegacySql": false,
        "useQueryCache": 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}}/projects/:projectId/queries \
  --header 'content-type: application/json' \
  --data '{
  "connectionProperties": [
    {
      "key": "",
      "value": ""
    }
  ],
  "continuous": false,
  "createSession": false,
  "defaultDataset": {
    "datasetId": "",
    "projectId": ""
  },
  "dryRun": false,
  "kind": "",
  "labels": {},
  "location": "",
  "maxResults": 0,
  "maximumBytesBilled": "",
  "parameterMode": "",
  "preserveNulls": false,
  "query": "",
  "queryParameters": [
    {
      "name": "",
      "parameterType": {
        "arrayType": "",
        "structTypes": [
          {
            "description": "",
            "name": "",
            "type": ""
          }
        ],
        "type": ""
      },
      "parameterValue": {
        "arrayValues": [],
        "structValues": {},
        "value": ""
      }
    }
  ],
  "requestId": "",
  "timeoutMs": 0,
  "useLegacySql": false,
  "useQueryCache": false
}'
echo '{
  "connectionProperties": [
    {
      "key": "",
      "value": ""
    }
  ],
  "continuous": false,
  "createSession": false,
  "defaultDataset": {
    "datasetId": "",
    "projectId": ""
  },
  "dryRun": false,
  "kind": "",
  "labels": {},
  "location": "",
  "maxResults": 0,
  "maximumBytesBilled": "",
  "parameterMode": "",
  "preserveNulls": false,
  "query": "",
  "queryParameters": [
    {
      "name": "",
      "parameterType": {
        "arrayType": "",
        "structTypes": [
          {
            "description": "",
            "name": "",
            "type": ""
          }
        ],
        "type": ""
      },
      "parameterValue": {
        "arrayValues": [],
        "structValues": {},
        "value": ""
      }
    }
  ],
  "requestId": "",
  "timeoutMs": 0,
  "useLegacySql": false,
  "useQueryCache": false
}' |  \
  http POST {{baseUrl}}/projects/:projectId/queries \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "connectionProperties": [\n    {\n      "key": "",\n      "value": ""\n    }\n  ],\n  "continuous": false,\n  "createSession": false,\n  "defaultDataset": {\n    "datasetId": "",\n    "projectId": ""\n  },\n  "dryRun": false,\n  "kind": "",\n  "labels": {},\n  "location": "",\n  "maxResults": 0,\n  "maximumBytesBilled": "",\n  "parameterMode": "",\n  "preserveNulls": false,\n  "query": "",\n  "queryParameters": [\n    {\n      "name": "",\n      "parameterType": {\n        "arrayType": "",\n        "structTypes": [\n          {\n            "description": "",\n            "name": "",\n            "type": ""\n          }\n        ],\n        "type": ""\n      },\n      "parameterValue": {\n        "arrayValues": [],\n        "structValues": {},\n        "value": ""\n      }\n    }\n  ],\n  "requestId": "",\n  "timeoutMs": 0,\n  "useLegacySql": false,\n  "useQueryCache": false\n}' \
  --output-document \
  - {{baseUrl}}/projects/:projectId/queries
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "connectionProperties": [
    [
      "key": "",
      "value": ""
    ]
  ],
  "continuous": false,
  "createSession": false,
  "defaultDataset": [
    "datasetId": "",
    "projectId": ""
  ],
  "dryRun": false,
  "kind": "",
  "labels": [],
  "location": "",
  "maxResults": 0,
  "maximumBytesBilled": "",
  "parameterMode": "",
  "preserveNulls": false,
  "query": "",
  "queryParameters": [
    [
      "name": "",
      "parameterType": [
        "arrayType": "",
        "structTypes": [
          [
            "description": "",
            "name": "",
            "type": ""
          ]
        ],
        "type": ""
      ],
      "parameterValue": [
        "arrayValues": [],
        "structValues": [],
        "value": ""
      ]
    ]
  ],
  "requestId": "",
  "timeoutMs": 0,
  "useLegacySql": false,
  "useQueryCache": false
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/queries")! 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 bigquery.models.delete
{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId
QUERY PARAMS

projectId
datasetId
modelId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId");

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

(client/delete "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"

	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/projects/:projectId/datasets/:datasetId/models/:modelId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"))
    .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}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .asString();
const 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}}/projects/:projectId/datasets/:datasetId/models/:modelId');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .delete(null)
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/models/:modelId',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId/models/:modelId'
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId');

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}}/projects/:projectId/datasets/:datasetId/models/:modelId'
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId';
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}}/projects/:projectId/datasets/:datasetId/models/:modelId"]
                                                       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}}/projects/:projectId/datasets/:datasetId/models/:modelId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId');
$request->setMethod(HTTP_METH_DELETE);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/projects/:projectId/datasets/:datasetId/models/:modelId")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"

response = requests.delete(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")

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/projects/:projectId/datasets/:datasetId/models/:modelId') do |req|
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId";

    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}}/projects/:projectId/datasets/:datasetId/models/:modelId
http DELETE {{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")! 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 bigquery.models.get
{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId
QUERY PARAMS

projectId
datasetId
modelId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId");

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

(client/get "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"

	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/projects/:projectId/datasets/:datasetId/models/:modelId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"))
    .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}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .asString();
const 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}}/projects/:projectId/datasets/:datasetId/models/:modelId');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/models/:modelId',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId/models/:modelId'
};

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

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

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId');

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}}/projects/:projectId/datasets/:datasetId/models/:modelId'
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId';
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}}/projects/:projectId/datasets/:datasetId/models/:modelId"]
                                                       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}}/projects/:projectId/datasets/:datasetId/models/:modelId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/projects/:projectId/datasets/:datasetId/models/:modelId")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")

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/projects/:projectId/datasets/:datasetId/models/:modelId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId";

    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}}/projects/:projectId/datasets/:datasetId/models/:modelId
http GET {{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")! 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 bigquery.models.list
{{baseUrl}}/projects/:projectId/datasets/:datasetId/models
QUERY PARAMS

projectId
datasetId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models");

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

(client/get "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models")
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/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/projects/:projectId/datasets/:datasetId/models HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models")
  .get()
  .build()

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

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

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/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}}/projects/:projectId/datasets/:datasetId/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}}/projects/:projectId/datasets/:datasetId/models" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/models');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/models');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/projects/:projectId/datasets/:datasetId/models")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/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/projects/:projectId/datasets/:datasetId/models') do |req|
end

puts response.status
puts response.body
use reqwest;

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/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()
PATCH bigquery.models.patch
{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId
QUERY PARAMS

projectId
datasetId
modelId
BODY json

{
  "bestTrialId": "",
  "creationTime": "",
  "defaultTrialId": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "featureColumns": [
    {
      "name": "",
      "type": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      }
    }
  ],
  "friendlyName": "",
  "hparamSearchSpaces": {
    "activationFn": {
      "candidates": []
    },
    "batchSize": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "boosterType": {},
    "colsampleBylevel": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "colsampleBynode": {},
    "colsampleBytree": {},
    "dartNormalizeType": {},
    "dropout": {},
    "hiddenUnits": {
      "candidates": [
        {
          "elements": []
        }
      ]
    },
    "l1Reg": {},
    "l2Reg": {},
    "learnRate": {},
    "maxTreeDepth": {},
    "minSplitLoss": {},
    "minTreeChildWeight": {},
    "numClusters": {},
    "numFactors": {},
    "numParallelTree": {},
    "optimizer": {},
    "subsample": {},
    "treeMethod": {},
    "walsAlpha": {}
  },
  "hparamTrials": [
    {
      "endTimeMs": "",
      "errorMessage": "",
      "evalLoss": "",
      "evaluationMetrics": {
        "arimaForecastingMetrics": {
          "arimaFittingMetrics": [
            {
              "aic": "",
              "logLikelihood": "",
              "variance": ""
            }
          ],
          "arimaSingleModelForecastingMetrics": [
            {
              "arimaFittingMetrics": {},
              "hasDrift": false,
              "hasHolidayEffect": false,
              "hasSpikesAndDips": false,
              "hasStepChanges": false,
              "nonSeasonalOrder": {
                "d": "",
                "p": "",
                "q": ""
              },
              "seasonalPeriods": [],
              "timeSeriesId": "",
              "timeSeriesIds": []
            }
          ],
          "hasDrift": [],
          "nonSeasonalOrder": [
            {}
          ],
          "seasonalPeriods": [],
          "timeSeriesId": []
        },
        "binaryClassificationMetrics": {
          "aggregateClassificationMetrics": {
            "accuracy": "",
            "f1Score": "",
            "logLoss": "",
            "precision": "",
            "recall": "",
            "rocAuc": "",
            "threshold": ""
          },
          "binaryConfusionMatrixList": [
            {
              "accuracy": "",
              "f1Score": "",
              "falseNegatives": "",
              "falsePositives": "",
              "positiveClassThreshold": "",
              "precision": "",
              "recall": "",
              "trueNegatives": "",
              "truePositives": ""
            }
          ],
          "negativeLabel": "",
          "positiveLabel": ""
        },
        "clusteringMetrics": {
          "clusters": [
            {
              "centroidId": "",
              "count": "",
              "featureValues": [
                {
                  "categoricalValue": {
                    "categoryCounts": [
                      {
                        "category": "",
                        "count": ""
                      }
                    ]
                  },
                  "featureColumn": "",
                  "numericalValue": ""
                }
              ]
            }
          ],
          "daviesBouldinIndex": "",
          "meanSquaredDistance": ""
        },
        "dimensionalityReductionMetrics": {
          "totalExplainedVarianceRatio": ""
        },
        "multiClassClassificationMetrics": {
          "aggregateClassificationMetrics": {},
          "confusionMatrixList": [
            {
              "confidenceThreshold": "",
              "rows": [
                {
                  "actualLabel": "",
                  "entries": [
                    {
                      "itemCount": "",
                      "predictedLabel": ""
                    }
                  ]
                }
              ]
            }
          ]
        },
        "rankingMetrics": {
          "averageRank": "",
          "meanAveragePrecision": "",
          "meanSquaredError": "",
          "normalizedDiscountedCumulativeGain": ""
        },
        "regressionMetrics": {
          "meanAbsoluteError": "",
          "meanSquaredError": "",
          "meanSquaredLogError": "",
          "medianAbsoluteError": "",
          "rSquared": ""
        }
      },
      "hparamTuningEvaluationMetrics": {},
      "hparams": {
        "adjustStepChanges": false,
        "autoArima": false,
        "autoArimaMaxOrder": "",
        "autoArimaMinOrder": "",
        "batchSize": "",
        "boosterType": "",
        "calculatePValues": false,
        "cleanSpikesAndDips": false,
        "colorSpace": "",
        "colsampleBylevel": "",
        "colsampleBynode": "",
        "colsampleBytree": "",
        "dartNormalizeType": "",
        "dataFrequency": "",
        "dataSplitColumn": "",
        "dataSplitEvalFraction": "",
        "dataSplitMethod": "",
        "decomposeTimeSeries": false,
        "distanceType": "",
        "dropout": "",
        "earlyStop": false,
        "enableGlobalExplain": false,
        "feedbackType": "",
        "hiddenUnits": [],
        "holidayRegion": "",
        "horizon": "",
        "hparamTuningObjectives": [],
        "includeDrift": false,
        "initialLearnRate": "",
        "inputLabelColumns": [],
        "integratedGradientsNumSteps": "",
        "itemColumn": "",
        "kmeansInitializationColumn": "",
        "kmeansInitializationMethod": "",
        "l1Regularization": "",
        "l2Regularization": "",
        "labelClassWeights": {},
        "learnRate": "",
        "learnRateStrategy": "",
        "lossType": "",
        "maxIterations": "",
        "maxParallelTrials": "",
        "maxTimeSeriesLength": "",
        "maxTreeDepth": "",
        "minRelativeProgress": "",
        "minSplitLoss": "",
        "minTimeSeriesLength": "",
        "minTreeChildWeight": "",
        "modelUri": "",
        "nonSeasonalOrder": {},
        "numClusters": "",
        "numFactors": "",
        "numParallelTree": "",
        "numTrials": "",
        "optimizationStrategy": "",
        "preserveInputStructs": false,
        "sampledShapleyNumPaths": "",
        "subsample": "",
        "timeSeriesDataColumn": "",
        "timeSeriesIdColumn": "",
        "timeSeriesIdColumns": [],
        "timeSeriesLengthFraction": "",
        "timeSeriesTimestampColumn": "",
        "treeMethod": "",
        "trendSmoothingWindowSize": "",
        "userColumn": "",
        "walsAlpha": "",
        "warmStart": false
      },
      "startTimeMs": "",
      "status": "",
      "trainingLoss": "",
      "trialId": ""
    }
  ],
  "labelColumns": [
    {}
  ],
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "modelReference": {
    "datasetId": "",
    "modelId": "",
    "projectId": ""
  },
  "modelType": "",
  "optimalTrialIds": [],
  "trainingRuns": [
    {
      "classLevelGlobalExplanations": [
        {
          "classLabel": "",
          "explanations": [
            {
              "attribution": "",
              "featureName": ""
            }
          ]
        }
      ],
      "dataSplitResult": {
        "evaluationTable": {
          "datasetId": "",
          "projectId": "",
          "tableId": ""
        },
        "testTable": {},
        "trainingTable": {}
      },
      "evaluationMetrics": {},
      "modelLevelGlobalExplanation": {},
      "results": [
        {
          "durationMs": "",
          "evalLoss": "",
          "index": 0,
          "learnRate": "",
          "trainingLoss": ""
        }
      ],
      "startTime": "",
      "trainingOptions": {},
      "trainingStartTime": "",
      "vertexAiModelId": "",
      "vertexAiModelVersion": ""
    }
  ]
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\n}");

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

(client/patch "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId" {:content-type :json
                                                                                                     :form-params {:bestTrialId ""
                                                                                                                   :creationTime ""
                                                                                                                   :defaultTrialId ""
                                                                                                                   :description ""
                                                                                                                   :encryptionConfiguration {:kmsKeyName ""}
                                                                                                                   :etag ""
                                                                                                                   :expirationTime ""
                                                                                                                   :featureColumns [{:name ""
                                                                                                                                     :type {:arrayElementType ""
                                                                                                                                            :structType {:fields []}
                                                                                                                                            :typeKind ""}}]
                                                                                                                   :friendlyName ""
                                                                                                                   :hparamSearchSpaces {:activationFn {:candidates []}
                                                                                                                                        :batchSize {:candidates {:candidates []}
                                                                                                                                                    :range {:max ""
                                                                                                                                                            :min ""}}
                                                                                                                                        :boosterType {}
                                                                                                                                        :colsampleBylevel {:candidates {:candidates []}
                                                                                                                                                           :range {:max ""
                                                                                                                                                                   :min ""}}
                                                                                                                                        :colsampleBynode {}
                                                                                                                                        :colsampleBytree {}
                                                                                                                                        :dartNormalizeType {}
                                                                                                                                        :dropout {}
                                                                                                                                        :hiddenUnits {:candidates [{:elements []}]}
                                                                                                                                        :l1Reg {}
                                                                                                                                        :l2Reg {}
                                                                                                                                        :learnRate {}
                                                                                                                                        :maxTreeDepth {}
                                                                                                                                        :minSplitLoss {}
                                                                                                                                        :minTreeChildWeight {}
                                                                                                                                        :numClusters {}
                                                                                                                                        :numFactors {}
                                                                                                                                        :numParallelTree {}
                                                                                                                                        :optimizer {}
                                                                                                                                        :subsample {}
                                                                                                                                        :treeMethod {}
                                                                                                                                        :walsAlpha {}}
                                                                                                                   :hparamTrials [{:endTimeMs ""
                                                                                                                                   :errorMessage ""
                                                                                                                                   :evalLoss ""
                                                                                                                                   :evaluationMetrics {:arimaForecastingMetrics {:arimaFittingMetrics [{:aic ""
                                                                                                                                                                                                        :logLikelihood ""
                                                                                                                                                                                                        :variance ""}]
                                                                                                                                                                                 :arimaSingleModelForecastingMetrics [{:arimaFittingMetrics {}
                                                                                                                                                                                                                       :hasDrift false
                                                                                                                                                                                                                       :hasHolidayEffect false
                                                                                                                                                                                                                       :hasSpikesAndDips false
                                                                                                                                                                                                                       :hasStepChanges false
                                                                                                                                                                                                                       :nonSeasonalOrder {:d ""
                                                                                                                                                                                                                                          :p ""
                                                                                                                                                                                                                                          :q ""}
                                                                                                                                                                                                                       :seasonalPeriods []
                                                                                                                                                                                                                       :timeSeriesId ""
                                                                                                                                                                                                                       :timeSeriesIds []}]
                                                                                                                                                                                 :hasDrift []
                                                                                                                                                                                 :nonSeasonalOrder [{}]
                                                                                                                                                                                 :seasonalPeriods []
                                                                                                                                                                                 :timeSeriesId []}
                                                                                                                                                       :binaryClassificationMetrics {:aggregateClassificationMetrics {:accuracy ""
                                                                                                                                                                                                                      :f1Score ""
                                                                                                                                                                                                                      :logLoss ""
                                                                                                                                                                                                                      :precision ""
                                                                                                                                                                                                                      :recall ""
                                                                                                                                                                                                                      :rocAuc ""
                                                                                                                                                                                                                      :threshold ""}
                                                                                                                                                                                     :binaryConfusionMatrixList [{:accuracy ""
                                                                                                                                                                                                                  :f1Score ""
                                                                                                                                                                                                                  :falseNegatives ""
                                                                                                                                                                                                                  :falsePositives ""
                                                                                                                                                                                                                  :positiveClassThreshold ""
                                                                                                                                                                                                                  :precision ""
                                                                                                                                                                                                                  :recall ""
                                                                                                                                                                                                                  :trueNegatives ""
                                                                                                                                                                                                                  :truePositives ""}]
                                                                                                                                                                                     :negativeLabel ""
                                                                                                                                                                                     :positiveLabel ""}
                                                                                                                                                       :clusteringMetrics {:clusters [{:centroidId ""
                                                                                                                                                                                       :count ""
                                                                                                                                                                                       :featureValues [{:categoricalValue {:categoryCounts [{:category ""
                                                                                                                                                                                                                                             :count ""}]}
                                                                                                                                                                                                        :featureColumn ""
                                                                                                                                                                                                        :numericalValue ""}]}]
                                                                                                                                                                           :daviesBouldinIndex ""
                                                                                                                                                                           :meanSquaredDistance ""}
                                                                                                                                                       :dimensionalityReductionMetrics {:totalExplainedVarianceRatio ""}
                                                                                                                                                       :multiClassClassificationMetrics {:aggregateClassificationMetrics {}
                                                                                                                                                                                         :confusionMatrixList [{:confidenceThreshold ""
                                                                                                                                                                                                                :rows [{:actualLabel ""
                                                                                                                                                                                                                        :entries [{:itemCount ""
                                                                                                                                                                                                                                   :predictedLabel ""}]}]}]}
                                                                                                                                                       :rankingMetrics {:averageRank ""
                                                                                                                                                                        :meanAveragePrecision ""
                                                                                                                                                                        :meanSquaredError ""
                                                                                                                                                                        :normalizedDiscountedCumulativeGain ""}
                                                                                                                                                       :regressionMetrics {:meanAbsoluteError ""
                                                                                                                                                                           :meanSquaredError ""
                                                                                                                                                                           :meanSquaredLogError ""
                                                                                                                                                                           :medianAbsoluteError ""
                                                                                                                                                                           :rSquared ""}}
                                                                                                                                   :hparamTuningEvaluationMetrics {}
                                                                                                                                   :hparams {:adjustStepChanges false
                                                                                                                                             :autoArima false
                                                                                                                                             :autoArimaMaxOrder ""
                                                                                                                                             :autoArimaMinOrder ""
                                                                                                                                             :batchSize ""
                                                                                                                                             :boosterType ""
                                                                                                                                             :calculatePValues false
                                                                                                                                             :cleanSpikesAndDips false
                                                                                                                                             :colorSpace ""
                                                                                                                                             :colsampleBylevel ""
                                                                                                                                             :colsampleBynode ""
                                                                                                                                             :colsampleBytree ""
                                                                                                                                             :dartNormalizeType ""
                                                                                                                                             :dataFrequency ""
                                                                                                                                             :dataSplitColumn ""
                                                                                                                                             :dataSplitEvalFraction ""
                                                                                                                                             :dataSplitMethod ""
                                                                                                                                             :decomposeTimeSeries false
                                                                                                                                             :distanceType ""
                                                                                                                                             :dropout ""
                                                                                                                                             :earlyStop false
                                                                                                                                             :enableGlobalExplain false
                                                                                                                                             :feedbackType ""
                                                                                                                                             :hiddenUnits []
                                                                                                                                             :holidayRegion ""
                                                                                                                                             :horizon ""
                                                                                                                                             :hparamTuningObjectives []
                                                                                                                                             :includeDrift false
                                                                                                                                             :initialLearnRate ""
                                                                                                                                             :inputLabelColumns []
                                                                                                                                             :integratedGradientsNumSteps ""
                                                                                                                                             :itemColumn ""
                                                                                                                                             :kmeansInitializationColumn ""
                                                                                                                                             :kmeansInitializationMethod ""
                                                                                                                                             :l1Regularization ""
                                                                                                                                             :l2Regularization ""
                                                                                                                                             :labelClassWeights {}
                                                                                                                                             :learnRate ""
                                                                                                                                             :learnRateStrategy ""
                                                                                                                                             :lossType ""
                                                                                                                                             :maxIterations ""
                                                                                                                                             :maxParallelTrials ""
                                                                                                                                             :maxTimeSeriesLength ""
                                                                                                                                             :maxTreeDepth ""
                                                                                                                                             :minRelativeProgress ""
                                                                                                                                             :minSplitLoss ""
                                                                                                                                             :minTimeSeriesLength ""
                                                                                                                                             :minTreeChildWeight ""
                                                                                                                                             :modelUri ""
                                                                                                                                             :nonSeasonalOrder {}
                                                                                                                                             :numClusters ""
                                                                                                                                             :numFactors ""
                                                                                                                                             :numParallelTree ""
                                                                                                                                             :numTrials ""
                                                                                                                                             :optimizationStrategy ""
                                                                                                                                             :preserveInputStructs false
                                                                                                                                             :sampledShapleyNumPaths ""
                                                                                                                                             :subsample ""
                                                                                                                                             :timeSeriesDataColumn ""
                                                                                                                                             :timeSeriesIdColumn ""
                                                                                                                                             :timeSeriesIdColumns []
                                                                                                                                             :timeSeriesLengthFraction ""
                                                                                                                                             :timeSeriesTimestampColumn ""
                                                                                                                                             :treeMethod ""
                                                                                                                                             :trendSmoothingWindowSize ""
                                                                                                                                             :userColumn ""
                                                                                                                                             :walsAlpha ""
                                                                                                                                             :warmStart false}
                                                                                                                                   :startTimeMs ""
                                                                                                                                   :status ""
                                                                                                                                   :trainingLoss ""
                                                                                                                                   :trialId ""}]
                                                                                                                   :labelColumns [{}]
                                                                                                                   :labels {}
                                                                                                                   :lastModifiedTime ""
                                                                                                                   :location ""
                                                                                                                   :modelReference {:datasetId ""
                                                                                                                                    :modelId ""
                                                                                                                                    :projectId ""}
                                                                                                                   :modelType ""
                                                                                                                   :optimalTrialIds []
                                                                                                                   :trainingRuns [{:classLevelGlobalExplanations [{:classLabel ""
                                                                                                                                                                   :explanations [{:attribution ""
                                                                                                                                                                                   :featureName ""}]}]
                                                                                                                                   :dataSplitResult {:evaluationTable {:datasetId ""
                                                                                                                                                                       :projectId ""
                                                                                                                                                                       :tableId ""}
                                                                                                                                                     :testTable {}
                                                                                                                                                     :trainingTable {}}
                                                                                                                                   :evaluationMetrics {}
                                                                                                                                   :modelLevelGlobalExplanation {}
                                                                                                                                   :results [{:durationMs ""
                                                                                                                                              :evalLoss ""
                                                                                                                                              :index 0
                                                                                                                                              :learnRate ""
                                                                                                                                              :trainingLoss ""}]
                                                                                                                                   :startTime ""
                                                                                                                                   :trainingOptions {}
                                                                                                                                   :trainingStartTime ""
                                                                                                                                   :vertexAiModelId ""
                                                                                                                                   :vertexAiModelVersion ""}]}})
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\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}}/projects/:projectId/datasets/:datasetId/models/:modelId"),
    Content = new StringContent("{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\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}}/projects/:projectId/datasets/:datasetId/models/:modelId");
var request = new RestRequest("", Method.Patch);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"

	payload := strings.NewReader("{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\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/projects/:projectId/datasets/:datasetId/models/:modelId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 8135

{
  "bestTrialId": "",
  "creationTime": "",
  "defaultTrialId": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "featureColumns": [
    {
      "name": "",
      "type": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      }
    }
  ],
  "friendlyName": "",
  "hparamSearchSpaces": {
    "activationFn": {
      "candidates": []
    },
    "batchSize": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "boosterType": {},
    "colsampleBylevel": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "colsampleBynode": {},
    "colsampleBytree": {},
    "dartNormalizeType": {},
    "dropout": {},
    "hiddenUnits": {
      "candidates": [
        {
          "elements": []
        }
      ]
    },
    "l1Reg": {},
    "l2Reg": {},
    "learnRate": {},
    "maxTreeDepth": {},
    "minSplitLoss": {},
    "minTreeChildWeight": {},
    "numClusters": {},
    "numFactors": {},
    "numParallelTree": {},
    "optimizer": {},
    "subsample": {},
    "treeMethod": {},
    "walsAlpha": {}
  },
  "hparamTrials": [
    {
      "endTimeMs": "",
      "errorMessage": "",
      "evalLoss": "",
      "evaluationMetrics": {
        "arimaForecastingMetrics": {
          "arimaFittingMetrics": [
            {
              "aic": "",
              "logLikelihood": "",
              "variance": ""
            }
          ],
          "arimaSingleModelForecastingMetrics": [
            {
              "arimaFittingMetrics": {},
              "hasDrift": false,
              "hasHolidayEffect": false,
              "hasSpikesAndDips": false,
              "hasStepChanges": false,
              "nonSeasonalOrder": {
                "d": "",
                "p": "",
                "q": ""
              },
              "seasonalPeriods": [],
              "timeSeriesId": "",
              "timeSeriesIds": []
            }
          ],
          "hasDrift": [],
          "nonSeasonalOrder": [
            {}
          ],
          "seasonalPeriods": [],
          "timeSeriesId": []
        },
        "binaryClassificationMetrics": {
          "aggregateClassificationMetrics": {
            "accuracy": "",
            "f1Score": "",
            "logLoss": "",
            "precision": "",
            "recall": "",
            "rocAuc": "",
            "threshold": ""
          },
          "binaryConfusionMatrixList": [
            {
              "accuracy": "",
              "f1Score": "",
              "falseNegatives": "",
              "falsePositives": "",
              "positiveClassThreshold": "",
              "precision": "",
              "recall": "",
              "trueNegatives": "",
              "truePositives": ""
            }
          ],
          "negativeLabel": "",
          "positiveLabel": ""
        },
        "clusteringMetrics": {
          "clusters": [
            {
              "centroidId": "",
              "count": "",
              "featureValues": [
                {
                  "categoricalValue": {
                    "categoryCounts": [
                      {
                        "category": "",
                        "count": ""
                      }
                    ]
                  },
                  "featureColumn": "",
                  "numericalValue": ""
                }
              ]
            }
          ],
          "daviesBouldinIndex": "",
          "meanSquaredDistance": ""
        },
        "dimensionalityReductionMetrics": {
          "totalExplainedVarianceRatio": ""
        },
        "multiClassClassificationMetrics": {
          "aggregateClassificationMetrics": {},
          "confusionMatrixList": [
            {
              "confidenceThreshold": "",
              "rows": [
                {
                  "actualLabel": "",
                  "entries": [
                    {
                      "itemCount": "",
                      "predictedLabel": ""
                    }
                  ]
                }
              ]
            }
          ]
        },
        "rankingMetrics": {
          "averageRank": "",
          "meanAveragePrecision": "",
          "meanSquaredError": "",
          "normalizedDiscountedCumulativeGain": ""
        },
        "regressionMetrics": {
          "meanAbsoluteError": "",
          "meanSquaredError": "",
          "meanSquaredLogError": "",
          "medianAbsoluteError": "",
          "rSquared": ""
        }
      },
      "hparamTuningEvaluationMetrics": {},
      "hparams": {
        "adjustStepChanges": false,
        "autoArima": false,
        "autoArimaMaxOrder": "",
        "autoArimaMinOrder": "",
        "batchSize": "",
        "boosterType": "",
        "calculatePValues": false,
        "cleanSpikesAndDips": false,
        "colorSpace": "",
        "colsampleBylevel": "",
        "colsampleBynode": "",
        "colsampleBytree": "",
        "dartNormalizeType": "",
        "dataFrequency": "",
        "dataSplitColumn": "",
        "dataSplitEvalFraction": "",
        "dataSplitMethod": "",
        "decomposeTimeSeries": false,
        "distanceType": "",
        "dropout": "",
        "earlyStop": false,
        "enableGlobalExplain": false,
        "feedbackType": "",
        "hiddenUnits": [],
        "holidayRegion": "",
        "horizon": "",
        "hparamTuningObjectives": [],
        "includeDrift": false,
        "initialLearnRate": "",
        "inputLabelColumns": [],
        "integratedGradientsNumSteps": "",
        "itemColumn": "",
        "kmeansInitializationColumn": "",
        "kmeansInitializationMethod": "",
        "l1Regularization": "",
        "l2Regularization": "",
        "labelClassWeights": {},
        "learnRate": "",
        "learnRateStrategy": "",
        "lossType": "",
        "maxIterations": "",
        "maxParallelTrials": "",
        "maxTimeSeriesLength": "",
        "maxTreeDepth": "",
        "minRelativeProgress": "",
        "minSplitLoss": "",
        "minTimeSeriesLength": "",
        "minTreeChildWeight": "",
        "modelUri": "",
        "nonSeasonalOrder": {},
        "numClusters": "",
        "numFactors": "",
        "numParallelTree": "",
        "numTrials": "",
        "optimizationStrategy": "",
        "preserveInputStructs": false,
        "sampledShapleyNumPaths": "",
        "subsample": "",
        "timeSeriesDataColumn": "",
        "timeSeriesIdColumn": "",
        "timeSeriesIdColumns": [],
        "timeSeriesLengthFraction": "",
        "timeSeriesTimestampColumn": "",
        "treeMethod": "",
        "trendSmoothingWindowSize": "",
        "userColumn": "",
        "walsAlpha": "",
        "warmStart": false
      },
      "startTimeMs": "",
      "status": "",
      "trainingLoss": "",
      "trialId": ""
    }
  ],
  "labelColumns": [
    {}
  ],
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "modelReference": {
    "datasetId": "",
    "modelId": "",
    "projectId": ""
  },
  "modelType": "",
  "optimalTrialIds": [],
  "trainingRuns": [
    {
      "classLevelGlobalExplanations": [
        {
          "classLabel": "",
          "explanations": [
            {
              "attribution": "",
              "featureName": ""
            }
          ]
        }
      ],
      "dataSplitResult": {
        "evaluationTable": {
          "datasetId": "",
          "projectId": "",
          "tableId": ""
        },
        "testTable": {},
        "trainingTable": {}
      },
      "evaluationMetrics": {},
      "modelLevelGlobalExplanation": {},
      "results": [
        {
          "durationMs": "",
          "evalLoss": "",
          "index": 0,
          "learnRate": "",
          "trainingLoss": ""
        }
      ],
      "startTime": "",
      "trainingOptions": {},
      "trainingStartTime": "",
      "vertexAiModelId": "",
      "vertexAiModelVersion": ""
    }
  ]
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"))
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\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  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .patch(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .header("content-type", "application/json")
  .body("{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\n}")
  .asString();
const data = JSON.stringify({
  bestTrialId: '',
  creationTime: '',
  defaultTrialId: '',
  description: '',
  encryptionConfiguration: {
    kmsKeyName: ''
  },
  etag: '',
  expirationTime: '',
  featureColumns: [
    {
      name: '',
      type: {
        arrayElementType: '',
        structType: {
          fields: []
        },
        typeKind: ''
      }
    }
  ],
  friendlyName: '',
  hparamSearchSpaces: {
    activationFn: {
      candidates: []
    },
    batchSize: {
      candidates: {
        candidates: []
      },
      range: {
        max: '',
        min: ''
      }
    },
    boosterType: {},
    colsampleBylevel: {
      candidates: {
        candidates: []
      },
      range: {
        max: '',
        min: ''
      }
    },
    colsampleBynode: {},
    colsampleBytree: {},
    dartNormalizeType: {},
    dropout: {},
    hiddenUnits: {
      candidates: [
        {
          elements: []
        }
      ]
    },
    l1Reg: {},
    l2Reg: {},
    learnRate: {},
    maxTreeDepth: {},
    minSplitLoss: {},
    minTreeChildWeight: {},
    numClusters: {},
    numFactors: {},
    numParallelTree: {},
    optimizer: {},
    subsample: {},
    treeMethod: {},
    walsAlpha: {}
  },
  hparamTrials: [
    {
      endTimeMs: '',
      errorMessage: '',
      evalLoss: '',
      evaluationMetrics: {
        arimaForecastingMetrics: {
          arimaFittingMetrics: [
            {
              aic: '',
              logLikelihood: '',
              variance: ''
            }
          ],
          arimaSingleModelForecastingMetrics: [
            {
              arimaFittingMetrics: {},
              hasDrift: false,
              hasHolidayEffect: false,
              hasSpikesAndDips: false,
              hasStepChanges: false,
              nonSeasonalOrder: {
                d: '',
                p: '',
                q: ''
              },
              seasonalPeriods: [],
              timeSeriesId: '',
              timeSeriesIds: []
            }
          ],
          hasDrift: [],
          nonSeasonalOrder: [
            {}
          ],
          seasonalPeriods: [],
          timeSeriesId: []
        },
        binaryClassificationMetrics: {
          aggregateClassificationMetrics: {
            accuracy: '',
            f1Score: '',
            logLoss: '',
            precision: '',
            recall: '',
            rocAuc: '',
            threshold: ''
          },
          binaryConfusionMatrixList: [
            {
              accuracy: '',
              f1Score: '',
              falseNegatives: '',
              falsePositives: '',
              positiveClassThreshold: '',
              precision: '',
              recall: '',
              trueNegatives: '',
              truePositives: ''
            }
          ],
          negativeLabel: '',
          positiveLabel: ''
        },
        clusteringMetrics: {
          clusters: [
            {
              centroidId: '',
              count: '',
              featureValues: [
                {
                  categoricalValue: {
                    categoryCounts: [
                      {
                        category: '',
                        count: ''
                      }
                    ]
                  },
                  featureColumn: '',
                  numericalValue: ''
                }
              ]
            }
          ],
          daviesBouldinIndex: '',
          meanSquaredDistance: ''
        },
        dimensionalityReductionMetrics: {
          totalExplainedVarianceRatio: ''
        },
        multiClassClassificationMetrics: {
          aggregateClassificationMetrics: {},
          confusionMatrixList: [
            {
              confidenceThreshold: '',
              rows: [
                {
                  actualLabel: '',
                  entries: [
                    {
                      itemCount: '',
                      predictedLabel: ''
                    }
                  ]
                }
              ]
            }
          ]
        },
        rankingMetrics: {
          averageRank: '',
          meanAveragePrecision: '',
          meanSquaredError: '',
          normalizedDiscountedCumulativeGain: ''
        },
        regressionMetrics: {
          meanAbsoluteError: '',
          meanSquaredError: '',
          meanSquaredLogError: '',
          medianAbsoluteError: '',
          rSquared: ''
        }
      },
      hparamTuningEvaluationMetrics: {},
      hparams: {
        adjustStepChanges: false,
        autoArima: false,
        autoArimaMaxOrder: '',
        autoArimaMinOrder: '',
        batchSize: '',
        boosterType: '',
        calculatePValues: false,
        cleanSpikesAndDips: false,
        colorSpace: '',
        colsampleBylevel: '',
        colsampleBynode: '',
        colsampleBytree: '',
        dartNormalizeType: '',
        dataFrequency: '',
        dataSplitColumn: '',
        dataSplitEvalFraction: '',
        dataSplitMethod: '',
        decomposeTimeSeries: false,
        distanceType: '',
        dropout: '',
        earlyStop: false,
        enableGlobalExplain: false,
        feedbackType: '',
        hiddenUnits: [],
        holidayRegion: '',
        horizon: '',
        hparamTuningObjectives: [],
        includeDrift: false,
        initialLearnRate: '',
        inputLabelColumns: [],
        integratedGradientsNumSteps: '',
        itemColumn: '',
        kmeansInitializationColumn: '',
        kmeansInitializationMethod: '',
        l1Regularization: '',
        l2Regularization: '',
        labelClassWeights: {},
        learnRate: '',
        learnRateStrategy: '',
        lossType: '',
        maxIterations: '',
        maxParallelTrials: '',
        maxTimeSeriesLength: '',
        maxTreeDepth: '',
        minRelativeProgress: '',
        minSplitLoss: '',
        minTimeSeriesLength: '',
        minTreeChildWeight: '',
        modelUri: '',
        nonSeasonalOrder: {},
        numClusters: '',
        numFactors: '',
        numParallelTree: '',
        numTrials: '',
        optimizationStrategy: '',
        preserveInputStructs: false,
        sampledShapleyNumPaths: '',
        subsample: '',
        timeSeriesDataColumn: '',
        timeSeriesIdColumn: '',
        timeSeriesIdColumns: [],
        timeSeriesLengthFraction: '',
        timeSeriesTimestampColumn: '',
        treeMethod: '',
        trendSmoothingWindowSize: '',
        userColumn: '',
        walsAlpha: '',
        warmStart: false
      },
      startTimeMs: '',
      status: '',
      trainingLoss: '',
      trialId: ''
    }
  ],
  labelColumns: [
    {}
  ],
  labels: {},
  lastModifiedTime: '',
  location: '',
  modelReference: {
    datasetId: '',
    modelId: '',
    projectId: ''
  },
  modelType: '',
  optimalTrialIds: [],
  trainingRuns: [
    {
      classLevelGlobalExplanations: [
        {
          classLabel: '',
          explanations: [
            {
              attribution: '',
              featureName: ''
            }
          ]
        }
      ],
      dataSplitResult: {
        evaluationTable: {
          datasetId: '',
          projectId: '',
          tableId: ''
        },
        testTable: {},
        trainingTable: {}
      },
      evaluationMetrics: {},
      modelLevelGlobalExplanation: {},
      results: [
        {
          durationMs: '',
          evalLoss: '',
          index: 0,
          learnRate: '',
          trainingLoss: ''
        }
      ],
      startTime: '',
      trainingOptions: {},
      trainingStartTime: '',
      vertexAiModelId: '',
      vertexAiModelVersion: ''
    }
  ]
});

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

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

xhr.open('PATCH', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId',
  headers: {'content-type': 'application/json'},
  data: {
    bestTrialId: '',
    creationTime: '',
    defaultTrialId: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    featureColumns: [
      {name: '', type: {arrayElementType: '', structType: {fields: []}, typeKind: ''}}
    ],
    friendlyName: '',
    hparamSearchSpaces: {
      activationFn: {candidates: []},
      batchSize: {candidates: {candidates: []}, range: {max: '', min: ''}},
      boosterType: {},
      colsampleBylevel: {candidates: {candidates: []}, range: {max: '', min: ''}},
      colsampleBynode: {},
      colsampleBytree: {},
      dartNormalizeType: {},
      dropout: {},
      hiddenUnits: {candidates: [{elements: []}]},
      l1Reg: {},
      l2Reg: {},
      learnRate: {},
      maxTreeDepth: {},
      minSplitLoss: {},
      minTreeChildWeight: {},
      numClusters: {},
      numFactors: {},
      numParallelTree: {},
      optimizer: {},
      subsample: {},
      treeMethod: {},
      walsAlpha: {}
    },
    hparamTrials: [
      {
        endTimeMs: '',
        errorMessage: '',
        evalLoss: '',
        evaluationMetrics: {
          arimaForecastingMetrics: {
            arimaFittingMetrics: [{aic: '', logLikelihood: '', variance: ''}],
            arimaSingleModelForecastingMetrics: [
              {
                arimaFittingMetrics: {},
                hasDrift: false,
                hasHolidayEffect: false,
                hasSpikesAndDips: false,
                hasStepChanges: false,
                nonSeasonalOrder: {d: '', p: '', q: ''},
                seasonalPeriods: [],
                timeSeriesId: '',
                timeSeriesIds: []
              }
            ],
            hasDrift: [],
            nonSeasonalOrder: [{}],
            seasonalPeriods: [],
            timeSeriesId: []
          },
          binaryClassificationMetrics: {
            aggregateClassificationMetrics: {
              accuracy: '',
              f1Score: '',
              logLoss: '',
              precision: '',
              recall: '',
              rocAuc: '',
              threshold: ''
            },
            binaryConfusionMatrixList: [
              {
                accuracy: '',
                f1Score: '',
                falseNegatives: '',
                falsePositives: '',
                positiveClassThreshold: '',
                precision: '',
                recall: '',
                trueNegatives: '',
                truePositives: ''
              }
            ],
            negativeLabel: '',
            positiveLabel: ''
          },
          clusteringMetrics: {
            clusters: [
              {
                centroidId: '',
                count: '',
                featureValues: [
                  {
                    categoricalValue: {categoryCounts: [{category: '', count: ''}]},
                    featureColumn: '',
                    numericalValue: ''
                  }
                ]
              }
            ],
            daviesBouldinIndex: '',
            meanSquaredDistance: ''
          },
          dimensionalityReductionMetrics: {totalExplainedVarianceRatio: ''},
          multiClassClassificationMetrics: {
            aggregateClassificationMetrics: {},
            confusionMatrixList: [
              {
                confidenceThreshold: '',
                rows: [{actualLabel: '', entries: [{itemCount: '', predictedLabel: ''}]}]
              }
            ]
          },
          rankingMetrics: {
            averageRank: '',
            meanAveragePrecision: '',
            meanSquaredError: '',
            normalizedDiscountedCumulativeGain: ''
          },
          regressionMetrics: {
            meanAbsoluteError: '',
            meanSquaredError: '',
            meanSquaredLogError: '',
            medianAbsoluteError: '',
            rSquared: ''
          }
        },
        hparamTuningEvaluationMetrics: {},
        hparams: {
          adjustStepChanges: false,
          autoArima: false,
          autoArimaMaxOrder: '',
          autoArimaMinOrder: '',
          batchSize: '',
          boosterType: '',
          calculatePValues: false,
          cleanSpikesAndDips: false,
          colorSpace: '',
          colsampleBylevel: '',
          colsampleBynode: '',
          colsampleBytree: '',
          dartNormalizeType: '',
          dataFrequency: '',
          dataSplitColumn: '',
          dataSplitEvalFraction: '',
          dataSplitMethod: '',
          decomposeTimeSeries: false,
          distanceType: '',
          dropout: '',
          earlyStop: false,
          enableGlobalExplain: false,
          feedbackType: '',
          hiddenUnits: [],
          holidayRegion: '',
          horizon: '',
          hparamTuningObjectives: [],
          includeDrift: false,
          initialLearnRate: '',
          inputLabelColumns: [],
          integratedGradientsNumSteps: '',
          itemColumn: '',
          kmeansInitializationColumn: '',
          kmeansInitializationMethod: '',
          l1Regularization: '',
          l2Regularization: '',
          labelClassWeights: {},
          learnRate: '',
          learnRateStrategy: '',
          lossType: '',
          maxIterations: '',
          maxParallelTrials: '',
          maxTimeSeriesLength: '',
          maxTreeDepth: '',
          minRelativeProgress: '',
          minSplitLoss: '',
          minTimeSeriesLength: '',
          minTreeChildWeight: '',
          modelUri: '',
          nonSeasonalOrder: {},
          numClusters: '',
          numFactors: '',
          numParallelTree: '',
          numTrials: '',
          optimizationStrategy: '',
          preserveInputStructs: false,
          sampledShapleyNumPaths: '',
          subsample: '',
          timeSeriesDataColumn: '',
          timeSeriesIdColumn: '',
          timeSeriesIdColumns: [],
          timeSeriesLengthFraction: '',
          timeSeriesTimestampColumn: '',
          treeMethod: '',
          trendSmoothingWindowSize: '',
          userColumn: '',
          walsAlpha: '',
          warmStart: false
        },
        startTimeMs: '',
        status: '',
        trainingLoss: '',
        trialId: ''
      }
    ],
    labelColumns: [{}],
    labels: {},
    lastModifiedTime: '',
    location: '',
    modelReference: {datasetId: '', modelId: '', projectId: ''},
    modelType: '',
    optimalTrialIds: [],
    trainingRuns: [
      {
        classLevelGlobalExplanations: [{classLabel: '', explanations: [{attribution: '', featureName: ''}]}],
        dataSplitResult: {
          evaluationTable: {datasetId: '', projectId: '', tableId: ''},
          testTable: {},
          trainingTable: {}
        },
        evaluationMetrics: {},
        modelLevelGlobalExplanation: {},
        results: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
        startTime: '',
        trainingOptions: {},
        trainingStartTime: '',
        vertexAiModelId: '',
        vertexAiModelVersion: ''
      }
    ]
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"bestTrialId":"","creationTime":"","defaultTrialId":"","description":"","encryptionConfiguration":{"kmsKeyName":""},"etag":"","expirationTime":"","featureColumns":[{"name":"","type":{"arrayElementType":"","structType":{"fields":[]},"typeKind":""}}],"friendlyName":"","hparamSearchSpaces":{"activationFn":{"candidates":[]},"batchSize":{"candidates":{"candidates":[]},"range":{"max":"","min":""}},"boosterType":{},"colsampleBylevel":{"candidates":{"candidates":[]},"range":{"max":"","min":""}},"colsampleBynode":{},"colsampleBytree":{},"dartNormalizeType":{},"dropout":{},"hiddenUnits":{"candidates":[{"elements":[]}]},"l1Reg":{},"l2Reg":{},"learnRate":{},"maxTreeDepth":{},"minSplitLoss":{},"minTreeChildWeight":{},"numClusters":{},"numFactors":{},"numParallelTree":{},"optimizer":{},"subsample":{},"treeMethod":{},"walsAlpha":{}},"hparamTrials":[{"endTimeMs":"","errorMessage":"","evalLoss":"","evaluationMetrics":{"arimaForecastingMetrics":{"arimaFittingMetrics":[{"aic":"","logLikelihood":"","variance":""}],"arimaSingleModelForecastingMetrics":[{"arimaFittingMetrics":{},"hasDrift":false,"hasHolidayEffect":false,"hasSpikesAndDips":false,"hasStepChanges":false,"nonSeasonalOrder":{"d":"","p":"","q":""},"seasonalPeriods":[],"timeSeriesId":"","timeSeriesIds":[]}],"hasDrift":[],"nonSeasonalOrder":[{}],"seasonalPeriods":[],"timeSeriesId":[]},"binaryClassificationMetrics":{"aggregateClassificationMetrics":{"accuracy":"","f1Score":"","logLoss":"","precision":"","recall":"","rocAuc":"","threshold":""},"binaryConfusionMatrixList":[{"accuracy":"","f1Score":"","falseNegatives":"","falsePositives":"","positiveClassThreshold":"","precision":"","recall":"","trueNegatives":"","truePositives":""}],"negativeLabel":"","positiveLabel":""},"clusteringMetrics":{"clusters":[{"centroidId":"","count":"","featureValues":[{"categoricalValue":{"categoryCounts":[{"category":"","count":""}]},"featureColumn":"","numericalValue":""}]}],"daviesBouldinIndex":"","meanSquaredDistance":""},"dimensionalityReductionMetrics":{"totalExplainedVarianceRatio":""},"multiClassClassificationMetrics":{"aggregateClassificationMetrics":{},"confusionMatrixList":[{"confidenceThreshold":"","rows":[{"actualLabel":"","entries":[{"itemCount":"","predictedLabel":""}]}]}]},"rankingMetrics":{"averageRank":"","meanAveragePrecision":"","meanSquaredError":"","normalizedDiscountedCumulativeGain":""},"regressionMetrics":{"meanAbsoluteError":"","meanSquaredError":"","meanSquaredLogError":"","medianAbsoluteError":"","rSquared":""}},"hparamTuningEvaluationMetrics":{},"hparams":{"adjustStepChanges":false,"autoArima":false,"autoArimaMaxOrder":"","autoArimaMinOrder":"","batchSize":"","boosterType":"","calculatePValues":false,"cleanSpikesAndDips":false,"colorSpace":"","colsampleBylevel":"","colsampleBynode":"","colsampleBytree":"","dartNormalizeType":"","dataFrequency":"","dataSplitColumn":"","dataSplitEvalFraction":"","dataSplitMethod":"","decomposeTimeSeries":false,"distanceType":"","dropout":"","earlyStop":false,"enableGlobalExplain":false,"feedbackType":"","hiddenUnits":[],"holidayRegion":"","horizon":"","hparamTuningObjectives":[],"includeDrift":false,"initialLearnRate":"","inputLabelColumns":[],"integratedGradientsNumSteps":"","itemColumn":"","kmeansInitializationColumn":"","kmeansInitializationMethod":"","l1Regularization":"","l2Regularization":"","labelClassWeights":{},"learnRate":"","learnRateStrategy":"","lossType":"","maxIterations":"","maxParallelTrials":"","maxTimeSeriesLength":"","maxTreeDepth":"","minRelativeProgress":"","minSplitLoss":"","minTimeSeriesLength":"","minTreeChildWeight":"","modelUri":"","nonSeasonalOrder":{},"numClusters":"","numFactors":"","numParallelTree":"","numTrials":"","optimizationStrategy":"","preserveInputStructs":false,"sampledShapleyNumPaths":"","subsample":"","timeSeriesDataColumn":"","timeSeriesIdColumn":"","timeSeriesIdColumns":[],"timeSeriesLengthFraction":"","timeSeriesTimestampColumn":"","treeMethod":"","trendSmoothingWindowSize":"","userColumn":"","walsAlpha":"","warmStart":false},"startTimeMs":"","status":"","trainingLoss":"","trialId":""}],"labelColumns":[{}],"labels":{},"lastModifiedTime":"","location":"","modelReference":{"datasetId":"","modelId":"","projectId":""},"modelType":"","optimalTrialIds":[],"trainingRuns":[{"classLevelGlobalExplanations":[{"classLabel":"","explanations":[{"attribution":"","featureName":""}]}],"dataSplitResult":{"evaluationTable":{"datasetId":"","projectId":"","tableId":""},"testTable":{},"trainingTable":{}},"evaluationMetrics":{},"modelLevelGlobalExplanation":{},"results":[{"durationMs":"","evalLoss":"","index":0,"learnRate":"","trainingLoss":""}],"startTime":"","trainingOptions":{},"trainingStartTime":"","vertexAiModelId":"","vertexAiModelVersion":""}]}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId',
  method: 'PATCH',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "bestTrialId": "",\n  "creationTime": "",\n  "defaultTrialId": "",\n  "description": "",\n  "encryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "etag": "",\n  "expirationTime": "",\n  "featureColumns": [\n    {\n      "name": "",\n      "type": {\n        "arrayElementType": "",\n        "structType": {\n          "fields": []\n        },\n        "typeKind": ""\n      }\n    }\n  ],\n  "friendlyName": "",\n  "hparamSearchSpaces": {\n    "activationFn": {\n      "candidates": []\n    },\n    "batchSize": {\n      "candidates": {\n        "candidates": []\n      },\n      "range": {\n        "max": "",\n        "min": ""\n      }\n    },\n    "boosterType": {},\n    "colsampleBylevel": {\n      "candidates": {\n        "candidates": []\n      },\n      "range": {\n        "max": "",\n        "min": ""\n      }\n    },\n    "colsampleBynode": {},\n    "colsampleBytree": {},\n    "dartNormalizeType": {},\n    "dropout": {},\n    "hiddenUnits": {\n      "candidates": [\n        {\n          "elements": []\n        }\n      ]\n    },\n    "l1Reg": {},\n    "l2Reg": {},\n    "learnRate": {},\n    "maxTreeDepth": {},\n    "minSplitLoss": {},\n    "minTreeChildWeight": {},\n    "numClusters": {},\n    "numFactors": {},\n    "numParallelTree": {},\n    "optimizer": {},\n    "subsample": {},\n    "treeMethod": {},\n    "walsAlpha": {}\n  },\n  "hparamTrials": [\n    {\n      "endTimeMs": "",\n      "errorMessage": "",\n      "evalLoss": "",\n      "evaluationMetrics": {\n        "arimaForecastingMetrics": {\n          "arimaFittingMetrics": [\n            {\n              "aic": "",\n              "logLikelihood": "",\n              "variance": ""\n            }\n          ],\n          "arimaSingleModelForecastingMetrics": [\n            {\n              "arimaFittingMetrics": {},\n              "hasDrift": false,\n              "hasHolidayEffect": false,\n              "hasSpikesAndDips": false,\n              "hasStepChanges": false,\n              "nonSeasonalOrder": {\n                "d": "",\n                "p": "",\n                "q": ""\n              },\n              "seasonalPeriods": [],\n              "timeSeriesId": "",\n              "timeSeriesIds": []\n            }\n          ],\n          "hasDrift": [],\n          "nonSeasonalOrder": [\n            {}\n          ],\n          "seasonalPeriods": [],\n          "timeSeriesId": []\n        },\n        "binaryClassificationMetrics": {\n          "aggregateClassificationMetrics": {\n            "accuracy": "",\n            "f1Score": "",\n            "logLoss": "",\n            "precision": "",\n            "recall": "",\n            "rocAuc": "",\n            "threshold": ""\n          },\n          "binaryConfusionMatrixList": [\n            {\n              "accuracy": "",\n              "f1Score": "",\n              "falseNegatives": "",\n              "falsePositives": "",\n              "positiveClassThreshold": "",\n              "precision": "",\n              "recall": "",\n              "trueNegatives": "",\n              "truePositives": ""\n            }\n          ],\n          "negativeLabel": "",\n          "positiveLabel": ""\n        },\n        "clusteringMetrics": {\n          "clusters": [\n            {\n              "centroidId": "",\n              "count": "",\n              "featureValues": [\n                {\n                  "categoricalValue": {\n                    "categoryCounts": [\n                      {\n                        "category": "",\n                        "count": ""\n                      }\n                    ]\n                  },\n                  "featureColumn": "",\n                  "numericalValue": ""\n                }\n              ]\n            }\n          ],\n          "daviesBouldinIndex": "",\n          "meanSquaredDistance": ""\n        },\n        "dimensionalityReductionMetrics": {\n          "totalExplainedVarianceRatio": ""\n        },\n        "multiClassClassificationMetrics": {\n          "aggregateClassificationMetrics": {},\n          "confusionMatrixList": [\n            {\n              "confidenceThreshold": "",\n              "rows": [\n                {\n                  "actualLabel": "",\n                  "entries": [\n                    {\n                      "itemCount": "",\n                      "predictedLabel": ""\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        "rankingMetrics": {\n          "averageRank": "",\n          "meanAveragePrecision": "",\n          "meanSquaredError": "",\n          "normalizedDiscountedCumulativeGain": ""\n        },\n        "regressionMetrics": {\n          "meanAbsoluteError": "",\n          "meanSquaredError": "",\n          "meanSquaredLogError": "",\n          "medianAbsoluteError": "",\n          "rSquared": ""\n        }\n      },\n      "hparamTuningEvaluationMetrics": {},\n      "hparams": {\n        "adjustStepChanges": false,\n        "autoArima": false,\n        "autoArimaMaxOrder": "",\n        "autoArimaMinOrder": "",\n        "batchSize": "",\n        "boosterType": "",\n        "calculatePValues": false,\n        "cleanSpikesAndDips": false,\n        "colorSpace": "",\n        "colsampleBylevel": "",\n        "colsampleBynode": "",\n        "colsampleBytree": "",\n        "dartNormalizeType": "",\n        "dataFrequency": "",\n        "dataSplitColumn": "",\n        "dataSplitEvalFraction": "",\n        "dataSplitMethod": "",\n        "decomposeTimeSeries": false,\n        "distanceType": "",\n        "dropout": "",\n        "earlyStop": false,\n        "enableGlobalExplain": false,\n        "feedbackType": "",\n        "hiddenUnits": [],\n        "holidayRegion": "",\n        "horizon": "",\n        "hparamTuningObjectives": [],\n        "includeDrift": false,\n        "initialLearnRate": "",\n        "inputLabelColumns": [],\n        "integratedGradientsNumSteps": "",\n        "itemColumn": "",\n        "kmeansInitializationColumn": "",\n        "kmeansInitializationMethod": "",\n        "l1Regularization": "",\n        "l2Regularization": "",\n        "labelClassWeights": {},\n        "learnRate": "",\n        "learnRateStrategy": "",\n        "lossType": "",\n        "maxIterations": "",\n        "maxParallelTrials": "",\n        "maxTimeSeriesLength": "",\n        "maxTreeDepth": "",\n        "minRelativeProgress": "",\n        "minSplitLoss": "",\n        "minTimeSeriesLength": "",\n        "minTreeChildWeight": "",\n        "modelUri": "",\n        "nonSeasonalOrder": {},\n        "numClusters": "",\n        "numFactors": "",\n        "numParallelTree": "",\n        "numTrials": "",\n        "optimizationStrategy": "",\n        "preserveInputStructs": false,\n        "sampledShapleyNumPaths": "",\n        "subsample": "",\n        "timeSeriesDataColumn": "",\n        "timeSeriesIdColumn": "",\n        "timeSeriesIdColumns": [],\n        "timeSeriesLengthFraction": "",\n        "timeSeriesTimestampColumn": "",\n        "treeMethod": "",\n        "trendSmoothingWindowSize": "",\n        "userColumn": "",\n        "walsAlpha": "",\n        "warmStart": false\n      },\n      "startTimeMs": "",\n      "status": "",\n      "trainingLoss": "",\n      "trialId": ""\n    }\n  ],\n  "labelColumns": [\n    {}\n  ],\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "modelReference": {\n    "datasetId": "",\n    "modelId": "",\n    "projectId": ""\n  },\n  "modelType": "",\n  "optimalTrialIds": [],\n  "trainingRuns": [\n    {\n      "classLevelGlobalExplanations": [\n        {\n          "classLabel": "",\n          "explanations": [\n            {\n              "attribution": "",\n              "featureName": ""\n            }\n          ]\n        }\n      ],\n      "dataSplitResult": {\n        "evaluationTable": {\n          "datasetId": "",\n          "projectId": "",\n          "tableId": ""\n        },\n        "testTable": {},\n        "trainingTable": {}\n      },\n      "evaluationMetrics": {},\n      "modelLevelGlobalExplanation": {},\n      "results": [\n        {\n          "durationMs": "",\n          "evalLoss": "",\n          "index": 0,\n          "learnRate": "",\n          "trainingLoss": ""\n        }\n      ],\n      "startTime": "",\n      "trainingOptions": {},\n      "trainingStartTime": "",\n      "vertexAiModelId": "",\n      "vertexAiModelVersion": ""\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  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")
  .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/projects/:projectId/datasets/:datasetId/models/:modelId',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  bestTrialId: '',
  creationTime: '',
  defaultTrialId: '',
  description: '',
  encryptionConfiguration: {kmsKeyName: ''},
  etag: '',
  expirationTime: '',
  featureColumns: [
    {name: '', type: {arrayElementType: '', structType: {fields: []}, typeKind: ''}}
  ],
  friendlyName: '',
  hparamSearchSpaces: {
    activationFn: {candidates: []},
    batchSize: {candidates: {candidates: []}, range: {max: '', min: ''}},
    boosterType: {},
    colsampleBylevel: {candidates: {candidates: []}, range: {max: '', min: ''}},
    colsampleBynode: {},
    colsampleBytree: {},
    dartNormalizeType: {},
    dropout: {},
    hiddenUnits: {candidates: [{elements: []}]},
    l1Reg: {},
    l2Reg: {},
    learnRate: {},
    maxTreeDepth: {},
    minSplitLoss: {},
    minTreeChildWeight: {},
    numClusters: {},
    numFactors: {},
    numParallelTree: {},
    optimizer: {},
    subsample: {},
    treeMethod: {},
    walsAlpha: {}
  },
  hparamTrials: [
    {
      endTimeMs: '',
      errorMessage: '',
      evalLoss: '',
      evaluationMetrics: {
        arimaForecastingMetrics: {
          arimaFittingMetrics: [{aic: '', logLikelihood: '', variance: ''}],
          arimaSingleModelForecastingMetrics: [
            {
              arimaFittingMetrics: {},
              hasDrift: false,
              hasHolidayEffect: false,
              hasSpikesAndDips: false,
              hasStepChanges: false,
              nonSeasonalOrder: {d: '', p: '', q: ''},
              seasonalPeriods: [],
              timeSeriesId: '',
              timeSeriesIds: []
            }
          ],
          hasDrift: [],
          nonSeasonalOrder: [{}],
          seasonalPeriods: [],
          timeSeriesId: []
        },
        binaryClassificationMetrics: {
          aggregateClassificationMetrics: {
            accuracy: '',
            f1Score: '',
            logLoss: '',
            precision: '',
            recall: '',
            rocAuc: '',
            threshold: ''
          },
          binaryConfusionMatrixList: [
            {
              accuracy: '',
              f1Score: '',
              falseNegatives: '',
              falsePositives: '',
              positiveClassThreshold: '',
              precision: '',
              recall: '',
              trueNegatives: '',
              truePositives: ''
            }
          ],
          negativeLabel: '',
          positiveLabel: ''
        },
        clusteringMetrics: {
          clusters: [
            {
              centroidId: '',
              count: '',
              featureValues: [
                {
                  categoricalValue: {categoryCounts: [{category: '', count: ''}]},
                  featureColumn: '',
                  numericalValue: ''
                }
              ]
            }
          ],
          daviesBouldinIndex: '',
          meanSquaredDistance: ''
        },
        dimensionalityReductionMetrics: {totalExplainedVarianceRatio: ''},
        multiClassClassificationMetrics: {
          aggregateClassificationMetrics: {},
          confusionMatrixList: [
            {
              confidenceThreshold: '',
              rows: [{actualLabel: '', entries: [{itemCount: '', predictedLabel: ''}]}]
            }
          ]
        },
        rankingMetrics: {
          averageRank: '',
          meanAveragePrecision: '',
          meanSquaredError: '',
          normalizedDiscountedCumulativeGain: ''
        },
        regressionMetrics: {
          meanAbsoluteError: '',
          meanSquaredError: '',
          meanSquaredLogError: '',
          medianAbsoluteError: '',
          rSquared: ''
        }
      },
      hparamTuningEvaluationMetrics: {},
      hparams: {
        adjustStepChanges: false,
        autoArima: false,
        autoArimaMaxOrder: '',
        autoArimaMinOrder: '',
        batchSize: '',
        boosterType: '',
        calculatePValues: false,
        cleanSpikesAndDips: false,
        colorSpace: '',
        colsampleBylevel: '',
        colsampleBynode: '',
        colsampleBytree: '',
        dartNormalizeType: '',
        dataFrequency: '',
        dataSplitColumn: '',
        dataSplitEvalFraction: '',
        dataSplitMethod: '',
        decomposeTimeSeries: false,
        distanceType: '',
        dropout: '',
        earlyStop: false,
        enableGlobalExplain: false,
        feedbackType: '',
        hiddenUnits: [],
        holidayRegion: '',
        horizon: '',
        hparamTuningObjectives: [],
        includeDrift: false,
        initialLearnRate: '',
        inputLabelColumns: [],
        integratedGradientsNumSteps: '',
        itemColumn: '',
        kmeansInitializationColumn: '',
        kmeansInitializationMethod: '',
        l1Regularization: '',
        l2Regularization: '',
        labelClassWeights: {},
        learnRate: '',
        learnRateStrategy: '',
        lossType: '',
        maxIterations: '',
        maxParallelTrials: '',
        maxTimeSeriesLength: '',
        maxTreeDepth: '',
        minRelativeProgress: '',
        minSplitLoss: '',
        minTimeSeriesLength: '',
        minTreeChildWeight: '',
        modelUri: '',
        nonSeasonalOrder: {},
        numClusters: '',
        numFactors: '',
        numParallelTree: '',
        numTrials: '',
        optimizationStrategy: '',
        preserveInputStructs: false,
        sampledShapleyNumPaths: '',
        subsample: '',
        timeSeriesDataColumn: '',
        timeSeriesIdColumn: '',
        timeSeriesIdColumns: [],
        timeSeriesLengthFraction: '',
        timeSeriesTimestampColumn: '',
        treeMethod: '',
        trendSmoothingWindowSize: '',
        userColumn: '',
        walsAlpha: '',
        warmStart: false
      },
      startTimeMs: '',
      status: '',
      trainingLoss: '',
      trialId: ''
    }
  ],
  labelColumns: [{}],
  labels: {},
  lastModifiedTime: '',
  location: '',
  modelReference: {datasetId: '', modelId: '', projectId: ''},
  modelType: '',
  optimalTrialIds: [],
  trainingRuns: [
    {
      classLevelGlobalExplanations: [{classLabel: '', explanations: [{attribution: '', featureName: ''}]}],
      dataSplitResult: {
        evaluationTable: {datasetId: '', projectId: '', tableId: ''},
        testTable: {},
        trainingTable: {}
      },
      evaluationMetrics: {},
      modelLevelGlobalExplanation: {},
      results: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
      startTime: '',
      trainingOptions: {},
      trainingStartTime: '',
      vertexAiModelId: '',
      vertexAiModelVersion: ''
    }
  ]
}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId',
  headers: {'content-type': 'application/json'},
  body: {
    bestTrialId: '',
    creationTime: '',
    defaultTrialId: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    featureColumns: [
      {name: '', type: {arrayElementType: '', structType: {fields: []}, typeKind: ''}}
    ],
    friendlyName: '',
    hparamSearchSpaces: {
      activationFn: {candidates: []},
      batchSize: {candidates: {candidates: []}, range: {max: '', min: ''}},
      boosterType: {},
      colsampleBylevel: {candidates: {candidates: []}, range: {max: '', min: ''}},
      colsampleBynode: {},
      colsampleBytree: {},
      dartNormalizeType: {},
      dropout: {},
      hiddenUnits: {candidates: [{elements: []}]},
      l1Reg: {},
      l2Reg: {},
      learnRate: {},
      maxTreeDepth: {},
      minSplitLoss: {},
      minTreeChildWeight: {},
      numClusters: {},
      numFactors: {},
      numParallelTree: {},
      optimizer: {},
      subsample: {},
      treeMethod: {},
      walsAlpha: {}
    },
    hparamTrials: [
      {
        endTimeMs: '',
        errorMessage: '',
        evalLoss: '',
        evaluationMetrics: {
          arimaForecastingMetrics: {
            arimaFittingMetrics: [{aic: '', logLikelihood: '', variance: ''}],
            arimaSingleModelForecastingMetrics: [
              {
                arimaFittingMetrics: {},
                hasDrift: false,
                hasHolidayEffect: false,
                hasSpikesAndDips: false,
                hasStepChanges: false,
                nonSeasonalOrder: {d: '', p: '', q: ''},
                seasonalPeriods: [],
                timeSeriesId: '',
                timeSeriesIds: []
              }
            ],
            hasDrift: [],
            nonSeasonalOrder: [{}],
            seasonalPeriods: [],
            timeSeriesId: []
          },
          binaryClassificationMetrics: {
            aggregateClassificationMetrics: {
              accuracy: '',
              f1Score: '',
              logLoss: '',
              precision: '',
              recall: '',
              rocAuc: '',
              threshold: ''
            },
            binaryConfusionMatrixList: [
              {
                accuracy: '',
                f1Score: '',
                falseNegatives: '',
                falsePositives: '',
                positiveClassThreshold: '',
                precision: '',
                recall: '',
                trueNegatives: '',
                truePositives: ''
              }
            ],
            negativeLabel: '',
            positiveLabel: ''
          },
          clusteringMetrics: {
            clusters: [
              {
                centroidId: '',
                count: '',
                featureValues: [
                  {
                    categoricalValue: {categoryCounts: [{category: '', count: ''}]},
                    featureColumn: '',
                    numericalValue: ''
                  }
                ]
              }
            ],
            daviesBouldinIndex: '',
            meanSquaredDistance: ''
          },
          dimensionalityReductionMetrics: {totalExplainedVarianceRatio: ''},
          multiClassClassificationMetrics: {
            aggregateClassificationMetrics: {},
            confusionMatrixList: [
              {
                confidenceThreshold: '',
                rows: [{actualLabel: '', entries: [{itemCount: '', predictedLabel: ''}]}]
              }
            ]
          },
          rankingMetrics: {
            averageRank: '',
            meanAveragePrecision: '',
            meanSquaredError: '',
            normalizedDiscountedCumulativeGain: ''
          },
          regressionMetrics: {
            meanAbsoluteError: '',
            meanSquaredError: '',
            meanSquaredLogError: '',
            medianAbsoluteError: '',
            rSquared: ''
          }
        },
        hparamTuningEvaluationMetrics: {},
        hparams: {
          adjustStepChanges: false,
          autoArima: false,
          autoArimaMaxOrder: '',
          autoArimaMinOrder: '',
          batchSize: '',
          boosterType: '',
          calculatePValues: false,
          cleanSpikesAndDips: false,
          colorSpace: '',
          colsampleBylevel: '',
          colsampleBynode: '',
          colsampleBytree: '',
          dartNormalizeType: '',
          dataFrequency: '',
          dataSplitColumn: '',
          dataSplitEvalFraction: '',
          dataSplitMethod: '',
          decomposeTimeSeries: false,
          distanceType: '',
          dropout: '',
          earlyStop: false,
          enableGlobalExplain: false,
          feedbackType: '',
          hiddenUnits: [],
          holidayRegion: '',
          horizon: '',
          hparamTuningObjectives: [],
          includeDrift: false,
          initialLearnRate: '',
          inputLabelColumns: [],
          integratedGradientsNumSteps: '',
          itemColumn: '',
          kmeansInitializationColumn: '',
          kmeansInitializationMethod: '',
          l1Regularization: '',
          l2Regularization: '',
          labelClassWeights: {},
          learnRate: '',
          learnRateStrategy: '',
          lossType: '',
          maxIterations: '',
          maxParallelTrials: '',
          maxTimeSeriesLength: '',
          maxTreeDepth: '',
          minRelativeProgress: '',
          minSplitLoss: '',
          minTimeSeriesLength: '',
          minTreeChildWeight: '',
          modelUri: '',
          nonSeasonalOrder: {},
          numClusters: '',
          numFactors: '',
          numParallelTree: '',
          numTrials: '',
          optimizationStrategy: '',
          preserveInputStructs: false,
          sampledShapleyNumPaths: '',
          subsample: '',
          timeSeriesDataColumn: '',
          timeSeriesIdColumn: '',
          timeSeriesIdColumns: [],
          timeSeriesLengthFraction: '',
          timeSeriesTimestampColumn: '',
          treeMethod: '',
          trendSmoothingWindowSize: '',
          userColumn: '',
          walsAlpha: '',
          warmStart: false
        },
        startTimeMs: '',
        status: '',
        trainingLoss: '',
        trialId: ''
      }
    ],
    labelColumns: [{}],
    labels: {},
    lastModifiedTime: '',
    location: '',
    modelReference: {datasetId: '', modelId: '', projectId: ''},
    modelType: '',
    optimalTrialIds: [],
    trainingRuns: [
      {
        classLevelGlobalExplanations: [{classLabel: '', explanations: [{attribution: '', featureName: ''}]}],
        dataSplitResult: {
          evaluationTable: {datasetId: '', projectId: '', tableId: ''},
          testTable: {},
          trainingTable: {}
        },
        evaluationMetrics: {},
        modelLevelGlobalExplanation: {},
        results: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
        startTime: '',
        trainingOptions: {},
        trainingStartTime: '',
        vertexAiModelId: '',
        vertexAiModelVersion: ''
      }
    ]
  },
  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}}/projects/:projectId/datasets/:datasetId/models/:modelId');

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

req.type('json');
req.send({
  bestTrialId: '',
  creationTime: '',
  defaultTrialId: '',
  description: '',
  encryptionConfiguration: {
    kmsKeyName: ''
  },
  etag: '',
  expirationTime: '',
  featureColumns: [
    {
      name: '',
      type: {
        arrayElementType: '',
        structType: {
          fields: []
        },
        typeKind: ''
      }
    }
  ],
  friendlyName: '',
  hparamSearchSpaces: {
    activationFn: {
      candidates: []
    },
    batchSize: {
      candidates: {
        candidates: []
      },
      range: {
        max: '',
        min: ''
      }
    },
    boosterType: {},
    colsampleBylevel: {
      candidates: {
        candidates: []
      },
      range: {
        max: '',
        min: ''
      }
    },
    colsampleBynode: {},
    colsampleBytree: {},
    dartNormalizeType: {},
    dropout: {},
    hiddenUnits: {
      candidates: [
        {
          elements: []
        }
      ]
    },
    l1Reg: {},
    l2Reg: {},
    learnRate: {},
    maxTreeDepth: {},
    minSplitLoss: {},
    minTreeChildWeight: {},
    numClusters: {},
    numFactors: {},
    numParallelTree: {},
    optimizer: {},
    subsample: {},
    treeMethod: {},
    walsAlpha: {}
  },
  hparamTrials: [
    {
      endTimeMs: '',
      errorMessage: '',
      evalLoss: '',
      evaluationMetrics: {
        arimaForecastingMetrics: {
          arimaFittingMetrics: [
            {
              aic: '',
              logLikelihood: '',
              variance: ''
            }
          ],
          arimaSingleModelForecastingMetrics: [
            {
              arimaFittingMetrics: {},
              hasDrift: false,
              hasHolidayEffect: false,
              hasSpikesAndDips: false,
              hasStepChanges: false,
              nonSeasonalOrder: {
                d: '',
                p: '',
                q: ''
              },
              seasonalPeriods: [],
              timeSeriesId: '',
              timeSeriesIds: []
            }
          ],
          hasDrift: [],
          nonSeasonalOrder: [
            {}
          ],
          seasonalPeriods: [],
          timeSeriesId: []
        },
        binaryClassificationMetrics: {
          aggregateClassificationMetrics: {
            accuracy: '',
            f1Score: '',
            logLoss: '',
            precision: '',
            recall: '',
            rocAuc: '',
            threshold: ''
          },
          binaryConfusionMatrixList: [
            {
              accuracy: '',
              f1Score: '',
              falseNegatives: '',
              falsePositives: '',
              positiveClassThreshold: '',
              precision: '',
              recall: '',
              trueNegatives: '',
              truePositives: ''
            }
          ],
          negativeLabel: '',
          positiveLabel: ''
        },
        clusteringMetrics: {
          clusters: [
            {
              centroidId: '',
              count: '',
              featureValues: [
                {
                  categoricalValue: {
                    categoryCounts: [
                      {
                        category: '',
                        count: ''
                      }
                    ]
                  },
                  featureColumn: '',
                  numericalValue: ''
                }
              ]
            }
          ],
          daviesBouldinIndex: '',
          meanSquaredDistance: ''
        },
        dimensionalityReductionMetrics: {
          totalExplainedVarianceRatio: ''
        },
        multiClassClassificationMetrics: {
          aggregateClassificationMetrics: {},
          confusionMatrixList: [
            {
              confidenceThreshold: '',
              rows: [
                {
                  actualLabel: '',
                  entries: [
                    {
                      itemCount: '',
                      predictedLabel: ''
                    }
                  ]
                }
              ]
            }
          ]
        },
        rankingMetrics: {
          averageRank: '',
          meanAveragePrecision: '',
          meanSquaredError: '',
          normalizedDiscountedCumulativeGain: ''
        },
        regressionMetrics: {
          meanAbsoluteError: '',
          meanSquaredError: '',
          meanSquaredLogError: '',
          medianAbsoluteError: '',
          rSquared: ''
        }
      },
      hparamTuningEvaluationMetrics: {},
      hparams: {
        adjustStepChanges: false,
        autoArima: false,
        autoArimaMaxOrder: '',
        autoArimaMinOrder: '',
        batchSize: '',
        boosterType: '',
        calculatePValues: false,
        cleanSpikesAndDips: false,
        colorSpace: '',
        colsampleBylevel: '',
        colsampleBynode: '',
        colsampleBytree: '',
        dartNormalizeType: '',
        dataFrequency: '',
        dataSplitColumn: '',
        dataSplitEvalFraction: '',
        dataSplitMethod: '',
        decomposeTimeSeries: false,
        distanceType: '',
        dropout: '',
        earlyStop: false,
        enableGlobalExplain: false,
        feedbackType: '',
        hiddenUnits: [],
        holidayRegion: '',
        horizon: '',
        hparamTuningObjectives: [],
        includeDrift: false,
        initialLearnRate: '',
        inputLabelColumns: [],
        integratedGradientsNumSteps: '',
        itemColumn: '',
        kmeansInitializationColumn: '',
        kmeansInitializationMethod: '',
        l1Regularization: '',
        l2Regularization: '',
        labelClassWeights: {},
        learnRate: '',
        learnRateStrategy: '',
        lossType: '',
        maxIterations: '',
        maxParallelTrials: '',
        maxTimeSeriesLength: '',
        maxTreeDepth: '',
        minRelativeProgress: '',
        minSplitLoss: '',
        minTimeSeriesLength: '',
        minTreeChildWeight: '',
        modelUri: '',
        nonSeasonalOrder: {},
        numClusters: '',
        numFactors: '',
        numParallelTree: '',
        numTrials: '',
        optimizationStrategy: '',
        preserveInputStructs: false,
        sampledShapleyNumPaths: '',
        subsample: '',
        timeSeriesDataColumn: '',
        timeSeriesIdColumn: '',
        timeSeriesIdColumns: [],
        timeSeriesLengthFraction: '',
        timeSeriesTimestampColumn: '',
        treeMethod: '',
        trendSmoothingWindowSize: '',
        userColumn: '',
        walsAlpha: '',
        warmStart: false
      },
      startTimeMs: '',
      status: '',
      trainingLoss: '',
      trialId: ''
    }
  ],
  labelColumns: [
    {}
  ],
  labels: {},
  lastModifiedTime: '',
  location: '',
  modelReference: {
    datasetId: '',
    modelId: '',
    projectId: ''
  },
  modelType: '',
  optimalTrialIds: [],
  trainingRuns: [
    {
      classLevelGlobalExplanations: [
        {
          classLabel: '',
          explanations: [
            {
              attribution: '',
              featureName: ''
            }
          ]
        }
      ],
      dataSplitResult: {
        evaluationTable: {
          datasetId: '',
          projectId: '',
          tableId: ''
        },
        testTable: {},
        trainingTable: {}
      },
      evaluationMetrics: {},
      modelLevelGlobalExplanation: {},
      results: [
        {
          durationMs: '',
          evalLoss: '',
          index: 0,
          learnRate: '',
          trainingLoss: ''
        }
      ],
      startTime: '',
      trainingOptions: {},
      trainingStartTime: '',
      vertexAiModelId: '',
      vertexAiModelVersion: ''
    }
  ]
});

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}}/projects/:projectId/datasets/:datasetId/models/:modelId',
  headers: {'content-type': 'application/json'},
  data: {
    bestTrialId: '',
    creationTime: '',
    defaultTrialId: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    featureColumns: [
      {name: '', type: {arrayElementType: '', structType: {fields: []}, typeKind: ''}}
    ],
    friendlyName: '',
    hparamSearchSpaces: {
      activationFn: {candidates: []},
      batchSize: {candidates: {candidates: []}, range: {max: '', min: ''}},
      boosterType: {},
      colsampleBylevel: {candidates: {candidates: []}, range: {max: '', min: ''}},
      colsampleBynode: {},
      colsampleBytree: {},
      dartNormalizeType: {},
      dropout: {},
      hiddenUnits: {candidates: [{elements: []}]},
      l1Reg: {},
      l2Reg: {},
      learnRate: {},
      maxTreeDepth: {},
      minSplitLoss: {},
      minTreeChildWeight: {},
      numClusters: {},
      numFactors: {},
      numParallelTree: {},
      optimizer: {},
      subsample: {},
      treeMethod: {},
      walsAlpha: {}
    },
    hparamTrials: [
      {
        endTimeMs: '',
        errorMessage: '',
        evalLoss: '',
        evaluationMetrics: {
          arimaForecastingMetrics: {
            arimaFittingMetrics: [{aic: '', logLikelihood: '', variance: ''}],
            arimaSingleModelForecastingMetrics: [
              {
                arimaFittingMetrics: {},
                hasDrift: false,
                hasHolidayEffect: false,
                hasSpikesAndDips: false,
                hasStepChanges: false,
                nonSeasonalOrder: {d: '', p: '', q: ''},
                seasonalPeriods: [],
                timeSeriesId: '',
                timeSeriesIds: []
              }
            ],
            hasDrift: [],
            nonSeasonalOrder: [{}],
            seasonalPeriods: [],
            timeSeriesId: []
          },
          binaryClassificationMetrics: {
            aggregateClassificationMetrics: {
              accuracy: '',
              f1Score: '',
              logLoss: '',
              precision: '',
              recall: '',
              rocAuc: '',
              threshold: ''
            },
            binaryConfusionMatrixList: [
              {
                accuracy: '',
                f1Score: '',
                falseNegatives: '',
                falsePositives: '',
                positiveClassThreshold: '',
                precision: '',
                recall: '',
                trueNegatives: '',
                truePositives: ''
              }
            ],
            negativeLabel: '',
            positiveLabel: ''
          },
          clusteringMetrics: {
            clusters: [
              {
                centroidId: '',
                count: '',
                featureValues: [
                  {
                    categoricalValue: {categoryCounts: [{category: '', count: ''}]},
                    featureColumn: '',
                    numericalValue: ''
                  }
                ]
              }
            ],
            daviesBouldinIndex: '',
            meanSquaredDistance: ''
          },
          dimensionalityReductionMetrics: {totalExplainedVarianceRatio: ''},
          multiClassClassificationMetrics: {
            aggregateClassificationMetrics: {},
            confusionMatrixList: [
              {
                confidenceThreshold: '',
                rows: [{actualLabel: '', entries: [{itemCount: '', predictedLabel: ''}]}]
              }
            ]
          },
          rankingMetrics: {
            averageRank: '',
            meanAveragePrecision: '',
            meanSquaredError: '',
            normalizedDiscountedCumulativeGain: ''
          },
          regressionMetrics: {
            meanAbsoluteError: '',
            meanSquaredError: '',
            meanSquaredLogError: '',
            medianAbsoluteError: '',
            rSquared: ''
          }
        },
        hparamTuningEvaluationMetrics: {},
        hparams: {
          adjustStepChanges: false,
          autoArima: false,
          autoArimaMaxOrder: '',
          autoArimaMinOrder: '',
          batchSize: '',
          boosterType: '',
          calculatePValues: false,
          cleanSpikesAndDips: false,
          colorSpace: '',
          colsampleBylevel: '',
          colsampleBynode: '',
          colsampleBytree: '',
          dartNormalizeType: '',
          dataFrequency: '',
          dataSplitColumn: '',
          dataSplitEvalFraction: '',
          dataSplitMethod: '',
          decomposeTimeSeries: false,
          distanceType: '',
          dropout: '',
          earlyStop: false,
          enableGlobalExplain: false,
          feedbackType: '',
          hiddenUnits: [],
          holidayRegion: '',
          horizon: '',
          hparamTuningObjectives: [],
          includeDrift: false,
          initialLearnRate: '',
          inputLabelColumns: [],
          integratedGradientsNumSteps: '',
          itemColumn: '',
          kmeansInitializationColumn: '',
          kmeansInitializationMethod: '',
          l1Regularization: '',
          l2Regularization: '',
          labelClassWeights: {},
          learnRate: '',
          learnRateStrategy: '',
          lossType: '',
          maxIterations: '',
          maxParallelTrials: '',
          maxTimeSeriesLength: '',
          maxTreeDepth: '',
          minRelativeProgress: '',
          minSplitLoss: '',
          minTimeSeriesLength: '',
          minTreeChildWeight: '',
          modelUri: '',
          nonSeasonalOrder: {},
          numClusters: '',
          numFactors: '',
          numParallelTree: '',
          numTrials: '',
          optimizationStrategy: '',
          preserveInputStructs: false,
          sampledShapleyNumPaths: '',
          subsample: '',
          timeSeriesDataColumn: '',
          timeSeriesIdColumn: '',
          timeSeriesIdColumns: [],
          timeSeriesLengthFraction: '',
          timeSeriesTimestampColumn: '',
          treeMethod: '',
          trendSmoothingWindowSize: '',
          userColumn: '',
          walsAlpha: '',
          warmStart: false
        },
        startTimeMs: '',
        status: '',
        trainingLoss: '',
        trialId: ''
      }
    ],
    labelColumns: [{}],
    labels: {},
    lastModifiedTime: '',
    location: '',
    modelReference: {datasetId: '', modelId: '', projectId: ''},
    modelType: '',
    optimalTrialIds: [],
    trainingRuns: [
      {
        classLevelGlobalExplanations: [{classLabel: '', explanations: [{attribution: '', featureName: ''}]}],
        dataSplitResult: {
          evaluationTable: {datasetId: '', projectId: '', tableId: ''},
          testTable: {},
          trainingTable: {}
        },
        evaluationMetrics: {},
        modelLevelGlobalExplanation: {},
        results: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
        startTime: '',
        trainingOptions: {},
        trainingStartTime: '',
        vertexAiModelId: '',
        vertexAiModelVersion: ''
      }
    ]
  }
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"bestTrialId":"","creationTime":"","defaultTrialId":"","description":"","encryptionConfiguration":{"kmsKeyName":""},"etag":"","expirationTime":"","featureColumns":[{"name":"","type":{"arrayElementType":"","structType":{"fields":[]},"typeKind":""}}],"friendlyName":"","hparamSearchSpaces":{"activationFn":{"candidates":[]},"batchSize":{"candidates":{"candidates":[]},"range":{"max":"","min":""}},"boosterType":{},"colsampleBylevel":{"candidates":{"candidates":[]},"range":{"max":"","min":""}},"colsampleBynode":{},"colsampleBytree":{},"dartNormalizeType":{},"dropout":{},"hiddenUnits":{"candidates":[{"elements":[]}]},"l1Reg":{},"l2Reg":{},"learnRate":{},"maxTreeDepth":{},"minSplitLoss":{},"minTreeChildWeight":{},"numClusters":{},"numFactors":{},"numParallelTree":{},"optimizer":{},"subsample":{},"treeMethod":{},"walsAlpha":{}},"hparamTrials":[{"endTimeMs":"","errorMessage":"","evalLoss":"","evaluationMetrics":{"arimaForecastingMetrics":{"arimaFittingMetrics":[{"aic":"","logLikelihood":"","variance":""}],"arimaSingleModelForecastingMetrics":[{"arimaFittingMetrics":{},"hasDrift":false,"hasHolidayEffect":false,"hasSpikesAndDips":false,"hasStepChanges":false,"nonSeasonalOrder":{"d":"","p":"","q":""},"seasonalPeriods":[],"timeSeriesId":"","timeSeriesIds":[]}],"hasDrift":[],"nonSeasonalOrder":[{}],"seasonalPeriods":[],"timeSeriesId":[]},"binaryClassificationMetrics":{"aggregateClassificationMetrics":{"accuracy":"","f1Score":"","logLoss":"","precision":"","recall":"","rocAuc":"","threshold":""},"binaryConfusionMatrixList":[{"accuracy":"","f1Score":"","falseNegatives":"","falsePositives":"","positiveClassThreshold":"","precision":"","recall":"","trueNegatives":"","truePositives":""}],"negativeLabel":"","positiveLabel":""},"clusteringMetrics":{"clusters":[{"centroidId":"","count":"","featureValues":[{"categoricalValue":{"categoryCounts":[{"category":"","count":""}]},"featureColumn":"","numericalValue":""}]}],"daviesBouldinIndex":"","meanSquaredDistance":""},"dimensionalityReductionMetrics":{"totalExplainedVarianceRatio":""},"multiClassClassificationMetrics":{"aggregateClassificationMetrics":{},"confusionMatrixList":[{"confidenceThreshold":"","rows":[{"actualLabel":"","entries":[{"itemCount":"","predictedLabel":""}]}]}]},"rankingMetrics":{"averageRank":"","meanAveragePrecision":"","meanSquaredError":"","normalizedDiscountedCumulativeGain":""},"regressionMetrics":{"meanAbsoluteError":"","meanSquaredError":"","meanSquaredLogError":"","medianAbsoluteError":"","rSquared":""}},"hparamTuningEvaluationMetrics":{},"hparams":{"adjustStepChanges":false,"autoArima":false,"autoArimaMaxOrder":"","autoArimaMinOrder":"","batchSize":"","boosterType":"","calculatePValues":false,"cleanSpikesAndDips":false,"colorSpace":"","colsampleBylevel":"","colsampleBynode":"","colsampleBytree":"","dartNormalizeType":"","dataFrequency":"","dataSplitColumn":"","dataSplitEvalFraction":"","dataSplitMethod":"","decomposeTimeSeries":false,"distanceType":"","dropout":"","earlyStop":false,"enableGlobalExplain":false,"feedbackType":"","hiddenUnits":[],"holidayRegion":"","horizon":"","hparamTuningObjectives":[],"includeDrift":false,"initialLearnRate":"","inputLabelColumns":[],"integratedGradientsNumSteps":"","itemColumn":"","kmeansInitializationColumn":"","kmeansInitializationMethod":"","l1Regularization":"","l2Regularization":"","labelClassWeights":{},"learnRate":"","learnRateStrategy":"","lossType":"","maxIterations":"","maxParallelTrials":"","maxTimeSeriesLength":"","maxTreeDepth":"","minRelativeProgress":"","minSplitLoss":"","minTimeSeriesLength":"","minTreeChildWeight":"","modelUri":"","nonSeasonalOrder":{},"numClusters":"","numFactors":"","numParallelTree":"","numTrials":"","optimizationStrategy":"","preserveInputStructs":false,"sampledShapleyNumPaths":"","subsample":"","timeSeriesDataColumn":"","timeSeriesIdColumn":"","timeSeriesIdColumns":[],"timeSeriesLengthFraction":"","timeSeriesTimestampColumn":"","treeMethod":"","trendSmoothingWindowSize":"","userColumn":"","walsAlpha":"","warmStart":false},"startTimeMs":"","status":"","trainingLoss":"","trialId":""}],"labelColumns":[{}],"labels":{},"lastModifiedTime":"","location":"","modelReference":{"datasetId":"","modelId":"","projectId":""},"modelType":"","optimalTrialIds":[],"trainingRuns":[{"classLevelGlobalExplanations":[{"classLabel":"","explanations":[{"attribution":"","featureName":""}]}],"dataSplitResult":{"evaluationTable":{"datasetId":"","projectId":"","tableId":""},"testTable":{},"trainingTable":{}},"evaluationMetrics":{},"modelLevelGlobalExplanation":{},"results":[{"durationMs":"","evalLoss":"","index":0,"learnRate":"","trainingLoss":""}],"startTime":"","trainingOptions":{},"trainingStartTime":"","vertexAiModelId":"","vertexAiModelVersion":""}]}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"bestTrialId": @"",
                              @"creationTime": @"",
                              @"defaultTrialId": @"",
                              @"description": @"",
                              @"encryptionConfiguration": @{ @"kmsKeyName": @"" },
                              @"etag": @"",
                              @"expirationTime": @"",
                              @"featureColumns": @[ @{ @"name": @"", @"type": @{ @"arrayElementType": @"", @"structType": @{ @"fields": @[  ] }, @"typeKind": @"" } } ],
                              @"friendlyName": @"",
                              @"hparamSearchSpaces": @{ @"activationFn": @{ @"candidates": @[  ] }, @"batchSize": @{ @"candidates": @{ @"candidates": @[  ] }, @"range": @{ @"max": @"", @"min": @"" } }, @"boosterType": @{  }, @"colsampleBylevel": @{ @"candidates": @{ @"candidates": @[  ] }, @"range": @{ @"max": @"", @"min": @"" } }, @"colsampleBynode": @{  }, @"colsampleBytree": @{  }, @"dartNormalizeType": @{  }, @"dropout": @{  }, @"hiddenUnits": @{ @"candidates": @[ @{ @"elements": @[  ] } ] }, @"l1Reg": @{  }, @"l2Reg": @{  }, @"learnRate": @{  }, @"maxTreeDepth": @{  }, @"minSplitLoss": @{  }, @"minTreeChildWeight": @{  }, @"numClusters": @{  }, @"numFactors": @{  }, @"numParallelTree": @{  }, @"optimizer": @{  }, @"subsample": @{  }, @"treeMethod": @{  }, @"walsAlpha": @{  } },
                              @"hparamTrials": @[ @{ @"endTimeMs": @"", @"errorMessage": @"", @"evalLoss": @"", @"evaluationMetrics": @{ @"arimaForecastingMetrics": @{ @"arimaFittingMetrics": @[ @{ @"aic": @"", @"logLikelihood": @"", @"variance": @"" } ], @"arimaSingleModelForecastingMetrics": @[ @{ @"arimaFittingMetrics": @{  }, @"hasDrift": @NO, @"hasHolidayEffect": @NO, @"hasSpikesAndDips": @NO, @"hasStepChanges": @NO, @"nonSeasonalOrder": @{ @"d": @"", @"p": @"", @"q": @"" }, @"seasonalPeriods": @[  ], @"timeSeriesId": @"", @"timeSeriesIds": @[  ] } ], @"hasDrift": @[  ], @"nonSeasonalOrder": @[ @{  } ], @"seasonalPeriods": @[  ], @"timeSeriesId": @[  ] }, @"binaryClassificationMetrics": @{ @"aggregateClassificationMetrics": @{ @"accuracy": @"", @"f1Score": @"", @"logLoss": @"", @"precision": @"", @"recall": @"", @"rocAuc": @"", @"threshold": @"" }, @"binaryConfusionMatrixList": @[ @{ @"accuracy": @"", @"f1Score": @"", @"falseNegatives": @"", @"falsePositives": @"", @"positiveClassThreshold": @"", @"precision": @"", @"recall": @"", @"trueNegatives": @"", @"truePositives": @"" } ], @"negativeLabel": @"", @"positiveLabel": @"" }, @"clusteringMetrics": @{ @"clusters": @[ @{ @"centroidId": @"", @"count": @"", @"featureValues": @[ @{ @"categoricalValue": @{ @"categoryCounts": @[ @{ @"category": @"", @"count": @"" } ] }, @"featureColumn": @"", @"numericalValue": @"" } ] } ], @"daviesBouldinIndex": @"", @"meanSquaredDistance": @"" }, @"dimensionalityReductionMetrics": @{ @"totalExplainedVarianceRatio": @"" }, @"multiClassClassificationMetrics": @{ @"aggregateClassificationMetrics": @{  }, @"confusionMatrixList": @[ @{ @"confidenceThreshold": @"", @"rows": @[ @{ @"actualLabel": @"", @"entries": @[ @{ @"itemCount": @"", @"predictedLabel": @"" } ] } ] } ] }, @"rankingMetrics": @{ @"averageRank": @"", @"meanAveragePrecision": @"", @"meanSquaredError": @"", @"normalizedDiscountedCumulativeGain": @"" }, @"regressionMetrics": @{ @"meanAbsoluteError": @"", @"meanSquaredError": @"", @"meanSquaredLogError": @"", @"medianAbsoluteError": @"", @"rSquared": @"" } }, @"hparamTuningEvaluationMetrics": @{  }, @"hparams": @{ @"adjustStepChanges": @NO, @"autoArima": @NO, @"autoArimaMaxOrder": @"", @"autoArimaMinOrder": @"", @"batchSize": @"", @"boosterType": @"", @"calculatePValues": @NO, @"cleanSpikesAndDips": @NO, @"colorSpace": @"", @"colsampleBylevel": @"", @"colsampleBynode": @"", @"colsampleBytree": @"", @"dartNormalizeType": @"", @"dataFrequency": @"", @"dataSplitColumn": @"", @"dataSplitEvalFraction": @"", @"dataSplitMethod": @"", @"decomposeTimeSeries": @NO, @"distanceType": @"", @"dropout": @"", @"earlyStop": @NO, @"enableGlobalExplain": @NO, @"feedbackType": @"", @"hiddenUnits": @[  ], @"holidayRegion": @"", @"horizon": @"", @"hparamTuningObjectives": @[  ], @"includeDrift": @NO, @"initialLearnRate": @"", @"inputLabelColumns": @[  ], @"integratedGradientsNumSteps": @"", @"itemColumn": @"", @"kmeansInitializationColumn": @"", @"kmeansInitializationMethod": @"", @"l1Regularization": @"", @"l2Regularization": @"", @"labelClassWeights": @{  }, @"learnRate": @"", @"learnRateStrategy": @"", @"lossType": @"", @"maxIterations": @"", @"maxParallelTrials": @"", @"maxTimeSeriesLength": @"", @"maxTreeDepth": @"", @"minRelativeProgress": @"", @"minSplitLoss": @"", @"minTimeSeriesLength": @"", @"minTreeChildWeight": @"", @"modelUri": @"", @"nonSeasonalOrder": @{  }, @"numClusters": @"", @"numFactors": @"", @"numParallelTree": @"", @"numTrials": @"", @"optimizationStrategy": @"", @"preserveInputStructs": @NO, @"sampledShapleyNumPaths": @"", @"subsample": @"", @"timeSeriesDataColumn": @"", @"timeSeriesIdColumn": @"", @"timeSeriesIdColumns": @[  ], @"timeSeriesLengthFraction": @"", @"timeSeriesTimestampColumn": @"", @"treeMethod": @"", @"trendSmoothingWindowSize": @"", @"userColumn": @"", @"walsAlpha": @"", @"warmStart": @NO }, @"startTimeMs": @"", @"status": @"", @"trainingLoss": @"", @"trialId": @"" } ],
                              @"labelColumns": @[ @{  } ],
                              @"labels": @{  },
                              @"lastModifiedTime": @"",
                              @"location": @"",
                              @"modelReference": @{ @"datasetId": @"", @"modelId": @"", @"projectId": @"" },
                              @"modelType": @"",
                              @"optimalTrialIds": @[  ],
                              @"trainingRuns": @[ @{ @"classLevelGlobalExplanations": @[ @{ @"classLabel": @"", @"explanations": @[ @{ @"attribution": @"", @"featureName": @"" } ] } ], @"dataSplitResult": @{ @"evaluationTable": @{ @"datasetId": @"", @"projectId": @"", @"tableId": @"" }, @"testTable": @{  }, @"trainingTable": @{  } }, @"evaluationMetrics": @{  }, @"modelLevelGlobalExplanation": @{  }, @"results": @[ @{ @"durationMs": @"", @"evalLoss": @"", @"index": @0, @"learnRate": @"", @"trainingLoss": @"" } ], @"startTime": @"", @"trainingOptions": @{  }, @"trainingStartTime": @"", @"vertexAiModelId": @"", @"vertexAiModelVersion": @"" } ] };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"]
                                                       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}}/projects/:projectId/datasets/:datasetId/models/:modelId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId",
  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([
    'bestTrialId' => '',
    'creationTime' => '',
    'defaultTrialId' => '',
    'description' => '',
    'encryptionConfiguration' => [
        'kmsKeyName' => ''
    ],
    'etag' => '',
    'expirationTime' => '',
    'featureColumns' => [
        [
                'name' => '',
                'type' => [
                                'arrayElementType' => '',
                                'structType' => [
                                                                'fields' => [
                                                                                                                                
                                                                ]
                                ],
                                'typeKind' => ''
                ]
        ]
    ],
    'friendlyName' => '',
    'hparamSearchSpaces' => [
        'activationFn' => [
                'candidates' => [
                                
                ]
        ],
        'batchSize' => [
                'candidates' => [
                                'candidates' => [
                                                                
                                ]
                ],
                'range' => [
                                'max' => '',
                                'min' => ''
                ]
        ],
        'boosterType' => [
                
        ],
        'colsampleBylevel' => [
                'candidates' => [
                                'candidates' => [
                                                                
                                ]
                ],
                'range' => [
                                'max' => '',
                                'min' => ''
                ]
        ],
        'colsampleBynode' => [
                
        ],
        'colsampleBytree' => [
                
        ],
        'dartNormalizeType' => [
                
        ],
        'dropout' => [
                
        ],
        'hiddenUnits' => [
                'candidates' => [
                                [
                                                                'elements' => [
                                                                                                                                
                                                                ]
                                ]
                ]
        ],
        'l1Reg' => [
                
        ],
        'l2Reg' => [
                
        ],
        'learnRate' => [
                
        ],
        'maxTreeDepth' => [
                
        ],
        'minSplitLoss' => [
                
        ],
        'minTreeChildWeight' => [
                
        ],
        'numClusters' => [
                
        ],
        'numFactors' => [
                
        ],
        'numParallelTree' => [
                
        ],
        'optimizer' => [
                
        ],
        'subsample' => [
                
        ],
        'treeMethod' => [
                
        ],
        'walsAlpha' => [
                
        ]
    ],
    'hparamTrials' => [
        [
                'endTimeMs' => '',
                'errorMessage' => '',
                'evalLoss' => '',
                'evaluationMetrics' => [
                                'arimaForecastingMetrics' => [
                                                                'arimaFittingMetrics' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'aic' => '',
                                                                                                                                                                                                                                                                'logLikelihood' => '',
                                                                                                                                                                                                                                                                'variance' => ''
                                                                                                                                ]
                                                                ],
                                                                'arimaSingleModelForecastingMetrics' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'arimaFittingMetrics' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'hasDrift' => null,
                                                                                                                                                                                                                                                                'hasHolidayEffect' => null,
                                                                                                                                                                                                                                                                'hasSpikesAndDips' => null,
                                                                                                                                                                                                                                                                'hasStepChanges' => null,
                                                                                                                                                                                                                                                                'nonSeasonalOrder' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'd' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'p' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'q' => ''
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'seasonalPeriods' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                'timeSeriesId' => '',
                                                                                                                                                                                                                                                                'timeSeriesIds' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'hasDrift' => [
                                                                                                                                
                                                                ],
                                                                'nonSeasonalOrder' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'seasonalPeriods' => [
                                                                                                                                
                                                                ],
                                                                'timeSeriesId' => [
                                                                                                                                
                                                                ]
                                ],
                                'binaryClassificationMetrics' => [
                                                                'aggregateClassificationMetrics' => [
                                                                                                                                'accuracy' => '',
                                                                                                                                'f1Score' => '',
                                                                                                                                'logLoss' => '',
                                                                                                                                'precision' => '',
                                                                                                                                'recall' => '',
                                                                                                                                'rocAuc' => '',
                                                                                                                                'threshold' => ''
                                                                ],
                                                                'binaryConfusionMatrixList' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'accuracy' => '',
                                                                                                                                                                                                                                                                'f1Score' => '',
                                                                                                                                                                                                                                                                'falseNegatives' => '',
                                                                                                                                                                                                                                                                'falsePositives' => '',
                                                                                                                                                                                                                                                                'positiveClassThreshold' => '',
                                                                                                                                                                                                                                                                'precision' => '',
                                                                                                                                                                                                                                                                'recall' => '',
                                                                                                                                                                                                                                                                'trueNegatives' => '',
                                                                                                                                                                                                                                                                'truePositives' => ''
                                                                                                                                ]
                                                                ],
                                                                'negativeLabel' => '',
                                                                'positiveLabel' => ''
                                ],
                                'clusteringMetrics' => [
                                                                'clusters' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'centroidId' => '',
                                                                                                                                                                                                                                                                'count' => '',
                                                                                                                                                                                                                                                                'featureValues' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'categoricalValue' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'categoryCounts' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'category' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'count' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'featureColumn' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'numericalValue' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ],
                                                                'daviesBouldinIndex' => '',
                                                                'meanSquaredDistance' => ''
                                ],
                                'dimensionalityReductionMetrics' => [
                                                                'totalExplainedVarianceRatio' => ''
                                ],
                                'multiClassClassificationMetrics' => [
                                                                'aggregateClassificationMetrics' => [
                                                                                                                                
                                                                ],
                                                                'confusionMatrixList' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'confidenceThreshold' => '',
                                                                                                                                                                                                                                                                'rows' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'actualLabel' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'entries' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'itemCount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'predictedLabel' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ]
                                ],
                                'rankingMetrics' => [
                                                                'averageRank' => '',
                                                                'meanAveragePrecision' => '',
                                                                'meanSquaredError' => '',
                                                                'normalizedDiscountedCumulativeGain' => ''
                                ],
                                'regressionMetrics' => [
                                                                'meanAbsoluteError' => '',
                                                                'meanSquaredError' => '',
                                                                'meanSquaredLogError' => '',
                                                                'medianAbsoluteError' => '',
                                                                'rSquared' => ''
                                ]
                ],
                'hparamTuningEvaluationMetrics' => [
                                
                ],
                'hparams' => [
                                'adjustStepChanges' => null,
                                'autoArima' => null,
                                'autoArimaMaxOrder' => '',
                                'autoArimaMinOrder' => '',
                                'batchSize' => '',
                                'boosterType' => '',
                                'calculatePValues' => null,
                                'cleanSpikesAndDips' => null,
                                'colorSpace' => '',
                                'colsampleBylevel' => '',
                                'colsampleBynode' => '',
                                'colsampleBytree' => '',
                                'dartNormalizeType' => '',
                                'dataFrequency' => '',
                                'dataSplitColumn' => '',
                                'dataSplitEvalFraction' => '',
                                'dataSplitMethod' => '',
                                'decomposeTimeSeries' => null,
                                'distanceType' => '',
                                'dropout' => '',
                                'earlyStop' => null,
                                'enableGlobalExplain' => null,
                                'feedbackType' => '',
                                'hiddenUnits' => [
                                                                
                                ],
                                'holidayRegion' => '',
                                'horizon' => '',
                                'hparamTuningObjectives' => [
                                                                
                                ],
                                'includeDrift' => null,
                                'initialLearnRate' => '',
                                'inputLabelColumns' => [
                                                                
                                ],
                                'integratedGradientsNumSteps' => '',
                                'itemColumn' => '',
                                'kmeansInitializationColumn' => '',
                                'kmeansInitializationMethod' => '',
                                'l1Regularization' => '',
                                'l2Regularization' => '',
                                'labelClassWeights' => [
                                                                
                                ],
                                'learnRate' => '',
                                'learnRateStrategy' => '',
                                'lossType' => '',
                                'maxIterations' => '',
                                'maxParallelTrials' => '',
                                'maxTimeSeriesLength' => '',
                                'maxTreeDepth' => '',
                                'minRelativeProgress' => '',
                                'minSplitLoss' => '',
                                'minTimeSeriesLength' => '',
                                'minTreeChildWeight' => '',
                                'modelUri' => '',
                                'nonSeasonalOrder' => [
                                                                
                                ],
                                'numClusters' => '',
                                'numFactors' => '',
                                'numParallelTree' => '',
                                'numTrials' => '',
                                'optimizationStrategy' => '',
                                'preserveInputStructs' => null,
                                'sampledShapleyNumPaths' => '',
                                'subsample' => '',
                                'timeSeriesDataColumn' => '',
                                'timeSeriesIdColumn' => '',
                                'timeSeriesIdColumns' => [
                                                                
                                ],
                                'timeSeriesLengthFraction' => '',
                                'timeSeriesTimestampColumn' => '',
                                'treeMethod' => '',
                                'trendSmoothingWindowSize' => '',
                                'userColumn' => '',
                                'walsAlpha' => '',
                                'warmStart' => null
                ],
                'startTimeMs' => '',
                'status' => '',
                'trainingLoss' => '',
                'trialId' => ''
        ]
    ],
    'labelColumns' => [
        [
                
        ]
    ],
    'labels' => [
        
    ],
    'lastModifiedTime' => '',
    'location' => '',
    'modelReference' => [
        'datasetId' => '',
        'modelId' => '',
        'projectId' => ''
    ],
    'modelType' => '',
    'optimalTrialIds' => [
        
    ],
    'trainingRuns' => [
        [
                'classLevelGlobalExplanations' => [
                                [
                                                                'classLabel' => '',
                                                                'explanations' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'attribution' => '',
                                                                                                                                                                                                                                                                'featureName' => ''
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'dataSplitResult' => [
                                'evaluationTable' => [
                                                                'datasetId' => '',
                                                                'projectId' => '',
                                                                'tableId' => ''
                                ],
                                'testTable' => [
                                                                
                                ],
                                'trainingTable' => [
                                                                
                                ]
                ],
                'evaluationMetrics' => [
                                
                ],
                'modelLevelGlobalExplanation' => [
                                
                ],
                'results' => [
                                [
                                                                'durationMs' => '',
                                                                'evalLoss' => '',
                                                                'index' => 0,
                                                                'learnRate' => '',
                                                                'trainingLoss' => ''
                                ]
                ],
                'startTime' => '',
                'trainingOptions' => [
                                
                ],
                'trainingStartTime' => '',
                'vertexAiModelId' => '',
                'vertexAiModelVersion' => ''
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-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}}/projects/:projectId/datasets/:datasetId/models/:modelId', [
  'body' => '{
  "bestTrialId": "",
  "creationTime": "",
  "defaultTrialId": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "featureColumns": [
    {
      "name": "",
      "type": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      }
    }
  ],
  "friendlyName": "",
  "hparamSearchSpaces": {
    "activationFn": {
      "candidates": []
    },
    "batchSize": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "boosterType": {},
    "colsampleBylevel": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "colsampleBynode": {},
    "colsampleBytree": {},
    "dartNormalizeType": {},
    "dropout": {},
    "hiddenUnits": {
      "candidates": [
        {
          "elements": []
        }
      ]
    },
    "l1Reg": {},
    "l2Reg": {},
    "learnRate": {},
    "maxTreeDepth": {},
    "minSplitLoss": {},
    "minTreeChildWeight": {},
    "numClusters": {},
    "numFactors": {},
    "numParallelTree": {},
    "optimizer": {},
    "subsample": {},
    "treeMethod": {},
    "walsAlpha": {}
  },
  "hparamTrials": [
    {
      "endTimeMs": "",
      "errorMessage": "",
      "evalLoss": "",
      "evaluationMetrics": {
        "arimaForecastingMetrics": {
          "arimaFittingMetrics": [
            {
              "aic": "",
              "logLikelihood": "",
              "variance": ""
            }
          ],
          "arimaSingleModelForecastingMetrics": [
            {
              "arimaFittingMetrics": {},
              "hasDrift": false,
              "hasHolidayEffect": false,
              "hasSpikesAndDips": false,
              "hasStepChanges": false,
              "nonSeasonalOrder": {
                "d": "",
                "p": "",
                "q": ""
              },
              "seasonalPeriods": [],
              "timeSeriesId": "",
              "timeSeriesIds": []
            }
          ],
          "hasDrift": [],
          "nonSeasonalOrder": [
            {}
          ],
          "seasonalPeriods": [],
          "timeSeriesId": []
        },
        "binaryClassificationMetrics": {
          "aggregateClassificationMetrics": {
            "accuracy": "",
            "f1Score": "",
            "logLoss": "",
            "precision": "",
            "recall": "",
            "rocAuc": "",
            "threshold": ""
          },
          "binaryConfusionMatrixList": [
            {
              "accuracy": "",
              "f1Score": "",
              "falseNegatives": "",
              "falsePositives": "",
              "positiveClassThreshold": "",
              "precision": "",
              "recall": "",
              "trueNegatives": "",
              "truePositives": ""
            }
          ],
          "negativeLabel": "",
          "positiveLabel": ""
        },
        "clusteringMetrics": {
          "clusters": [
            {
              "centroidId": "",
              "count": "",
              "featureValues": [
                {
                  "categoricalValue": {
                    "categoryCounts": [
                      {
                        "category": "",
                        "count": ""
                      }
                    ]
                  },
                  "featureColumn": "",
                  "numericalValue": ""
                }
              ]
            }
          ],
          "daviesBouldinIndex": "",
          "meanSquaredDistance": ""
        },
        "dimensionalityReductionMetrics": {
          "totalExplainedVarianceRatio": ""
        },
        "multiClassClassificationMetrics": {
          "aggregateClassificationMetrics": {},
          "confusionMatrixList": [
            {
              "confidenceThreshold": "",
              "rows": [
                {
                  "actualLabel": "",
                  "entries": [
                    {
                      "itemCount": "",
                      "predictedLabel": ""
                    }
                  ]
                }
              ]
            }
          ]
        },
        "rankingMetrics": {
          "averageRank": "",
          "meanAveragePrecision": "",
          "meanSquaredError": "",
          "normalizedDiscountedCumulativeGain": ""
        },
        "regressionMetrics": {
          "meanAbsoluteError": "",
          "meanSquaredError": "",
          "meanSquaredLogError": "",
          "medianAbsoluteError": "",
          "rSquared": ""
        }
      },
      "hparamTuningEvaluationMetrics": {},
      "hparams": {
        "adjustStepChanges": false,
        "autoArima": false,
        "autoArimaMaxOrder": "",
        "autoArimaMinOrder": "",
        "batchSize": "",
        "boosterType": "",
        "calculatePValues": false,
        "cleanSpikesAndDips": false,
        "colorSpace": "",
        "colsampleBylevel": "",
        "colsampleBynode": "",
        "colsampleBytree": "",
        "dartNormalizeType": "",
        "dataFrequency": "",
        "dataSplitColumn": "",
        "dataSplitEvalFraction": "",
        "dataSplitMethod": "",
        "decomposeTimeSeries": false,
        "distanceType": "",
        "dropout": "",
        "earlyStop": false,
        "enableGlobalExplain": false,
        "feedbackType": "",
        "hiddenUnits": [],
        "holidayRegion": "",
        "horizon": "",
        "hparamTuningObjectives": [],
        "includeDrift": false,
        "initialLearnRate": "",
        "inputLabelColumns": [],
        "integratedGradientsNumSteps": "",
        "itemColumn": "",
        "kmeansInitializationColumn": "",
        "kmeansInitializationMethod": "",
        "l1Regularization": "",
        "l2Regularization": "",
        "labelClassWeights": {},
        "learnRate": "",
        "learnRateStrategy": "",
        "lossType": "",
        "maxIterations": "",
        "maxParallelTrials": "",
        "maxTimeSeriesLength": "",
        "maxTreeDepth": "",
        "minRelativeProgress": "",
        "minSplitLoss": "",
        "minTimeSeriesLength": "",
        "minTreeChildWeight": "",
        "modelUri": "",
        "nonSeasonalOrder": {},
        "numClusters": "",
        "numFactors": "",
        "numParallelTree": "",
        "numTrials": "",
        "optimizationStrategy": "",
        "preserveInputStructs": false,
        "sampledShapleyNumPaths": "",
        "subsample": "",
        "timeSeriesDataColumn": "",
        "timeSeriesIdColumn": "",
        "timeSeriesIdColumns": [],
        "timeSeriesLengthFraction": "",
        "timeSeriesTimestampColumn": "",
        "treeMethod": "",
        "trendSmoothingWindowSize": "",
        "userColumn": "",
        "walsAlpha": "",
        "warmStart": false
      },
      "startTimeMs": "",
      "status": "",
      "trainingLoss": "",
      "trialId": ""
    }
  ],
  "labelColumns": [
    {}
  ],
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "modelReference": {
    "datasetId": "",
    "modelId": "",
    "projectId": ""
  },
  "modelType": "",
  "optimalTrialIds": [],
  "trainingRuns": [
    {
      "classLevelGlobalExplanations": [
        {
          "classLabel": "",
          "explanations": [
            {
              "attribution": "",
              "featureName": ""
            }
          ]
        }
      ],
      "dataSplitResult": {
        "evaluationTable": {
          "datasetId": "",
          "projectId": "",
          "tableId": ""
        },
        "testTable": {},
        "trainingTable": {}
      },
      "evaluationMetrics": {},
      "modelLevelGlobalExplanation": {},
      "results": [
        {
          "durationMs": "",
          "evalLoss": "",
          "index": 0,
          "learnRate": "",
          "trainingLoss": ""
        }
      ],
      "startTime": "",
      "trainingOptions": {},
      "trainingStartTime": "",
      "vertexAiModelId": "",
      "vertexAiModelVersion": ""
    }
  ]
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'bestTrialId' => '',
  'creationTime' => '',
  'defaultTrialId' => '',
  'description' => '',
  'encryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'etag' => '',
  'expirationTime' => '',
  'featureColumns' => [
    [
        'name' => '',
        'type' => [
                'arrayElementType' => '',
                'structType' => [
                                'fields' => [
                                                                
                                ]
                ],
                'typeKind' => ''
        ]
    ]
  ],
  'friendlyName' => '',
  'hparamSearchSpaces' => [
    'activationFn' => [
        'candidates' => [
                
        ]
    ],
    'batchSize' => [
        'candidates' => [
                'candidates' => [
                                
                ]
        ],
        'range' => [
                'max' => '',
                'min' => ''
        ]
    ],
    'boosterType' => [
        
    ],
    'colsampleBylevel' => [
        'candidates' => [
                'candidates' => [
                                
                ]
        ],
        'range' => [
                'max' => '',
                'min' => ''
        ]
    ],
    'colsampleBynode' => [
        
    ],
    'colsampleBytree' => [
        
    ],
    'dartNormalizeType' => [
        
    ],
    'dropout' => [
        
    ],
    'hiddenUnits' => [
        'candidates' => [
                [
                                'elements' => [
                                                                
                                ]
                ]
        ]
    ],
    'l1Reg' => [
        
    ],
    'l2Reg' => [
        
    ],
    'learnRate' => [
        
    ],
    'maxTreeDepth' => [
        
    ],
    'minSplitLoss' => [
        
    ],
    'minTreeChildWeight' => [
        
    ],
    'numClusters' => [
        
    ],
    'numFactors' => [
        
    ],
    'numParallelTree' => [
        
    ],
    'optimizer' => [
        
    ],
    'subsample' => [
        
    ],
    'treeMethod' => [
        
    ],
    'walsAlpha' => [
        
    ]
  ],
  'hparamTrials' => [
    [
        'endTimeMs' => '',
        'errorMessage' => '',
        'evalLoss' => '',
        'evaluationMetrics' => [
                'arimaForecastingMetrics' => [
                                'arimaFittingMetrics' => [
                                                                [
                                                                                                                                'aic' => '',
                                                                                                                                'logLikelihood' => '',
                                                                                                                                'variance' => ''
                                                                ]
                                ],
                                'arimaSingleModelForecastingMetrics' => [
                                                                [
                                                                                                                                'arimaFittingMetrics' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'hasDrift' => null,
                                                                                                                                'hasHolidayEffect' => null,
                                                                                                                                'hasSpikesAndDips' => null,
                                                                                                                                'hasStepChanges' => null,
                                                                                                                                'nonSeasonalOrder' => [
                                                                                                                                                                                                                                                                'd' => '',
                                                                                                                                                                                                                                                                'p' => '',
                                                                                                                                                                                                                                                                'q' => ''
                                                                                                                                ],
                                                                                                                                'seasonalPeriods' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'timeSeriesId' => '',
                                                                                                                                'timeSeriesIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'hasDrift' => [
                                                                
                                ],
                                'nonSeasonalOrder' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'seasonalPeriods' => [
                                                                
                                ],
                                'timeSeriesId' => [
                                                                
                                ]
                ],
                'binaryClassificationMetrics' => [
                                'aggregateClassificationMetrics' => [
                                                                'accuracy' => '',
                                                                'f1Score' => '',
                                                                'logLoss' => '',
                                                                'precision' => '',
                                                                'recall' => '',
                                                                'rocAuc' => '',
                                                                'threshold' => ''
                                ],
                                'binaryConfusionMatrixList' => [
                                                                [
                                                                                                                                'accuracy' => '',
                                                                                                                                'f1Score' => '',
                                                                                                                                'falseNegatives' => '',
                                                                                                                                'falsePositives' => '',
                                                                                                                                'positiveClassThreshold' => '',
                                                                                                                                'precision' => '',
                                                                                                                                'recall' => '',
                                                                                                                                'trueNegatives' => '',
                                                                                                                                'truePositives' => ''
                                                                ]
                                ],
                                'negativeLabel' => '',
                                'positiveLabel' => ''
                ],
                'clusteringMetrics' => [
                                'clusters' => [
                                                                [
                                                                                                                                'centroidId' => '',
                                                                                                                                'count' => '',
                                                                                                                                'featureValues' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'categoricalValue' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'categoryCounts' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'category' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'count' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'featureColumn' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'numericalValue' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ]
                                ],
                                'daviesBouldinIndex' => '',
                                'meanSquaredDistance' => ''
                ],
                'dimensionalityReductionMetrics' => [
                                'totalExplainedVarianceRatio' => ''
                ],
                'multiClassClassificationMetrics' => [
                                'aggregateClassificationMetrics' => [
                                                                
                                ],
                                'confusionMatrixList' => [
                                                                [
                                                                                                                                'confidenceThreshold' => '',
                                                                                                                                'rows' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'actualLabel' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'entries' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'itemCount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'predictedLabel' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'rankingMetrics' => [
                                'averageRank' => '',
                                'meanAveragePrecision' => '',
                                'meanSquaredError' => '',
                                'normalizedDiscountedCumulativeGain' => ''
                ],
                'regressionMetrics' => [
                                'meanAbsoluteError' => '',
                                'meanSquaredError' => '',
                                'meanSquaredLogError' => '',
                                'medianAbsoluteError' => '',
                                'rSquared' => ''
                ]
        ],
        'hparamTuningEvaluationMetrics' => [
                
        ],
        'hparams' => [
                'adjustStepChanges' => null,
                'autoArima' => null,
                'autoArimaMaxOrder' => '',
                'autoArimaMinOrder' => '',
                'batchSize' => '',
                'boosterType' => '',
                'calculatePValues' => null,
                'cleanSpikesAndDips' => null,
                'colorSpace' => '',
                'colsampleBylevel' => '',
                'colsampleBynode' => '',
                'colsampleBytree' => '',
                'dartNormalizeType' => '',
                'dataFrequency' => '',
                'dataSplitColumn' => '',
                'dataSplitEvalFraction' => '',
                'dataSplitMethod' => '',
                'decomposeTimeSeries' => null,
                'distanceType' => '',
                'dropout' => '',
                'earlyStop' => null,
                'enableGlobalExplain' => null,
                'feedbackType' => '',
                'hiddenUnits' => [
                                
                ],
                'holidayRegion' => '',
                'horizon' => '',
                'hparamTuningObjectives' => [
                                
                ],
                'includeDrift' => null,
                'initialLearnRate' => '',
                'inputLabelColumns' => [
                                
                ],
                'integratedGradientsNumSteps' => '',
                'itemColumn' => '',
                'kmeansInitializationColumn' => '',
                'kmeansInitializationMethod' => '',
                'l1Regularization' => '',
                'l2Regularization' => '',
                'labelClassWeights' => [
                                
                ],
                'learnRate' => '',
                'learnRateStrategy' => '',
                'lossType' => '',
                'maxIterations' => '',
                'maxParallelTrials' => '',
                'maxTimeSeriesLength' => '',
                'maxTreeDepth' => '',
                'minRelativeProgress' => '',
                'minSplitLoss' => '',
                'minTimeSeriesLength' => '',
                'minTreeChildWeight' => '',
                'modelUri' => '',
                'nonSeasonalOrder' => [
                                
                ],
                'numClusters' => '',
                'numFactors' => '',
                'numParallelTree' => '',
                'numTrials' => '',
                'optimizationStrategy' => '',
                'preserveInputStructs' => null,
                'sampledShapleyNumPaths' => '',
                'subsample' => '',
                'timeSeriesDataColumn' => '',
                'timeSeriesIdColumn' => '',
                'timeSeriesIdColumns' => [
                                
                ],
                'timeSeriesLengthFraction' => '',
                'timeSeriesTimestampColumn' => '',
                'treeMethod' => '',
                'trendSmoothingWindowSize' => '',
                'userColumn' => '',
                'walsAlpha' => '',
                'warmStart' => null
        ],
        'startTimeMs' => '',
        'status' => '',
        'trainingLoss' => '',
        'trialId' => ''
    ]
  ],
  'labelColumns' => [
    [
        
    ]
  ],
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'modelReference' => [
    'datasetId' => '',
    'modelId' => '',
    'projectId' => ''
  ],
  'modelType' => '',
  'optimalTrialIds' => [
    
  ],
  'trainingRuns' => [
    [
        'classLevelGlobalExplanations' => [
                [
                                'classLabel' => '',
                                'explanations' => [
                                                                [
                                                                                                                                'attribution' => '',
                                                                                                                                'featureName' => ''
                                                                ]
                                ]
                ]
        ],
        'dataSplitResult' => [
                'evaluationTable' => [
                                'datasetId' => '',
                                'projectId' => '',
                                'tableId' => ''
                ],
                'testTable' => [
                                
                ],
                'trainingTable' => [
                                
                ]
        ],
        'evaluationMetrics' => [
                
        ],
        'modelLevelGlobalExplanation' => [
                
        ],
        'results' => [
                [
                                'durationMs' => '',
                                'evalLoss' => '',
                                'index' => 0,
                                'learnRate' => '',
                                'trainingLoss' => ''
                ]
        ],
        'startTime' => '',
        'trainingOptions' => [
                
        ],
        'trainingStartTime' => '',
        'vertexAiModelId' => '',
        'vertexAiModelVersion' => ''
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'bestTrialId' => '',
  'creationTime' => '',
  'defaultTrialId' => '',
  'description' => '',
  'encryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'etag' => '',
  'expirationTime' => '',
  'featureColumns' => [
    [
        'name' => '',
        'type' => [
                'arrayElementType' => '',
                'structType' => [
                                'fields' => [
                                                                
                                ]
                ],
                'typeKind' => ''
        ]
    ]
  ],
  'friendlyName' => '',
  'hparamSearchSpaces' => [
    'activationFn' => [
        'candidates' => [
                
        ]
    ],
    'batchSize' => [
        'candidates' => [
                'candidates' => [
                                
                ]
        ],
        'range' => [
                'max' => '',
                'min' => ''
        ]
    ],
    'boosterType' => [
        
    ],
    'colsampleBylevel' => [
        'candidates' => [
                'candidates' => [
                                
                ]
        ],
        'range' => [
                'max' => '',
                'min' => ''
        ]
    ],
    'colsampleBynode' => [
        
    ],
    'colsampleBytree' => [
        
    ],
    'dartNormalizeType' => [
        
    ],
    'dropout' => [
        
    ],
    'hiddenUnits' => [
        'candidates' => [
                [
                                'elements' => [
                                                                
                                ]
                ]
        ]
    ],
    'l1Reg' => [
        
    ],
    'l2Reg' => [
        
    ],
    'learnRate' => [
        
    ],
    'maxTreeDepth' => [
        
    ],
    'minSplitLoss' => [
        
    ],
    'minTreeChildWeight' => [
        
    ],
    'numClusters' => [
        
    ],
    'numFactors' => [
        
    ],
    'numParallelTree' => [
        
    ],
    'optimizer' => [
        
    ],
    'subsample' => [
        
    ],
    'treeMethod' => [
        
    ],
    'walsAlpha' => [
        
    ]
  ],
  'hparamTrials' => [
    [
        'endTimeMs' => '',
        'errorMessage' => '',
        'evalLoss' => '',
        'evaluationMetrics' => [
                'arimaForecastingMetrics' => [
                                'arimaFittingMetrics' => [
                                                                [
                                                                                                                                'aic' => '',
                                                                                                                                'logLikelihood' => '',
                                                                                                                                'variance' => ''
                                                                ]
                                ],
                                'arimaSingleModelForecastingMetrics' => [
                                                                [
                                                                                                                                'arimaFittingMetrics' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'hasDrift' => null,
                                                                                                                                'hasHolidayEffect' => null,
                                                                                                                                'hasSpikesAndDips' => null,
                                                                                                                                'hasStepChanges' => null,
                                                                                                                                'nonSeasonalOrder' => [
                                                                                                                                                                                                                                                                'd' => '',
                                                                                                                                                                                                                                                                'p' => '',
                                                                                                                                                                                                                                                                'q' => ''
                                                                                                                                ],
                                                                                                                                'seasonalPeriods' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'timeSeriesId' => '',
                                                                                                                                'timeSeriesIds' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ]
                                ],
                                'hasDrift' => [
                                                                
                                ],
                                'nonSeasonalOrder' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'seasonalPeriods' => [
                                                                
                                ],
                                'timeSeriesId' => [
                                                                
                                ]
                ],
                'binaryClassificationMetrics' => [
                                'aggregateClassificationMetrics' => [
                                                                'accuracy' => '',
                                                                'f1Score' => '',
                                                                'logLoss' => '',
                                                                'precision' => '',
                                                                'recall' => '',
                                                                'rocAuc' => '',
                                                                'threshold' => ''
                                ],
                                'binaryConfusionMatrixList' => [
                                                                [
                                                                                                                                'accuracy' => '',
                                                                                                                                'f1Score' => '',
                                                                                                                                'falseNegatives' => '',
                                                                                                                                'falsePositives' => '',
                                                                                                                                'positiveClassThreshold' => '',
                                                                                                                                'precision' => '',
                                                                                                                                'recall' => '',
                                                                                                                                'trueNegatives' => '',
                                                                                                                                'truePositives' => ''
                                                                ]
                                ],
                                'negativeLabel' => '',
                                'positiveLabel' => ''
                ],
                'clusteringMetrics' => [
                                'clusters' => [
                                                                [
                                                                                                                                'centroidId' => '',
                                                                                                                                'count' => '',
                                                                                                                                'featureValues' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'categoricalValue' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'categoryCounts' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'category' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'count' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ],
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'featureColumn' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'numericalValue' => ''
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ]
                                ],
                                'daviesBouldinIndex' => '',
                                'meanSquaredDistance' => ''
                ],
                'dimensionalityReductionMetrics' => [
                                'totalExplainedVarianceRatio' => ''
                ],
                'multiClassClassificationMetrics' => [
                                'aggregateClassificationMetrics' => [
                                                                
                                ],
                                'confusionMatrixList' => [
                                                                [
                                                                                                                                'confidenceThreshold' => '',
                                                                                                                                'rows' => [
                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'actualLabel' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'entries' => [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                [
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'itemCount' => '',
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                'predictedLabel' => ''
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                                ]
                                                                                                                                                                                                                                                                ]
                                                                                                                                ]
                                                                ]
                                ]
                ],
                'rankingMetrics' => [
                                'averageRank' => '',
                                'meanAveragePrecision' => '',
                                'meanSquaredError' => '',
                                'normalizedDiscountedCumulativeGain' => ''
                ],
                'regressionMetrics' => [
                                'meanAbsoluteError' => '',
                                'meanSquaredError' => '',
                                'meanSquaredLogError' => '',
                                'medianAbsoluteError' => '',
                                'rSquared' => ''
                ]
        ],
        'hparamTuningEvaluationMetrics' => [
                
        ],
        'hparams' => [
                'adjustStepChanges' => null,
                'autoArima' => null,
                'autoArimaMaxOrder' => '',
                'autoArimaMinOrder' => '',
                'batchSize' => '',
                'boosterType' => '',
                'calculatePValues' => null,
                'cleanSpikesAndDips' => null,
                'colorSpace' => '',
                'colsampleBylevel' => '',
                'colsampleBynode' => '',
                'colsampleBytree' => '',
                'dartNormalizeType' => '',
                'dataFrequency' => '',
                'dataSplitColumn' => '',
                'dataSplitEvalFraction' => '',
                'dataSplitMethod' => '',
                'decomposeTimeSeries' => null,
                'distanceType' => '',
                'dropout' => '',
                'earlyStop' => null,
                'enableGlobalExplain' => null,
                'feedbackType' => '',
                'hiddenUnits' => [
                                
                ],
                'holidayRegion' => '',
                'horizon' => '',
                'hparamTuningObjectives' => [
                                
                ],
                'includeDrift' => null,
                'initialLearnRate' => '',
                'inputLabelColumns' => [
                                
                ],
                'integratedGradientsNumSteps' => '',
                'itemColumn' => '',
                'kmeansInitializationColumn' => '',
                'kmeansInitializationMethod' => '',
                'l1Regularization' => '',
                'l2Regularization' => '',
                'labelClassWeights' => [
                                
                ],
                'learnRate' => '',
                'learnRateStrategy' => '',
                'lossType' => '',
                'maxIterations' => '',
                'maxParallelTrials' => '',
                'maxTimeSeriesLength' => '',
                'maxTreeDepth' => '',
                'minRelativeProgress' => '',
                'minSplitLoss' => '',
                'minTimeSeriesLength' => '',
                'minTreeChildWeight' => '',
                'modelUri' => '',
                'nonSeasonalOrder' => [
                                
                ],
                'numClusters' => '',
                'numFactors' => '',
                'numParallelTree' => '',
                'numTrials' => '',
                'optimizationStrategy' => '',
                'preserveInputStructs' => null,
                'sampledShapleyNumPaths' => '',
                'subsample' => '',
                'timeSeriesDataColumn' => '',
                'timeSeriesIdColumn' => '',
                'timeSeriesIdColumns' => [
                                
                ],
                'timeSeriesLengthFraction' => '',
                'timeSeriesTimestampColumn' => '',
                'treeMethod' => '',
                'trendSmoothingWindowSize' => '',
                'userColumn' => '',
                'walsAlpha' => '',
                'warmStart' => null
        ],
        'startTimeMs' => '',
        'status' => '',
        'trainingLoss' => '',
        'trialId' => ''
    ]
  ],
  'labelColumns' => [
    [
        
    ]
  ],
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'modelReference' => [
    'datasetId' => '',
    'modelId' => '',
    'projectId' => ''
  ],
  'modelType' => '',
  'optimalTrialIds' => [
    
  ],
  'trainingRuns' => [
    [
        'classLevelGlobalExplanations' => [
                [
                                'classLabel' => '',
                                'explanations' => [
                                                                [
                                                                                                                                'attribution' => '',
                                                                                                                                'featureName' => ''
                                                                ]
                                ]
                ]
        ],
        'dataSplitResult' => [
                'evaluationTable' => [
                                'datasetId' => '',
                                'projectId' => '',
                                'tableId' => ''
                ],
                'testTable' => [
                                
                ],
                'trainingTable' => [
                                
                ]
        ],
        'evaluationMetrics' => [
                
        ],
        'modelLevelGlobalExplanation' => [
                
        ],
        'results' => [
                [
                                'durationMs' => '',
                                'evalLoss' => '',
                                'index' => 0,
                                'learnRate' => '',
                                'trainingLoss' => ''
                ]
        ],
        'startTime' => '',
        'trainingOptions' => [
                
        ],
        'trainingStartTime' => '',
        'vertexAiModelId' => '',
        'vertexAiModelVersion' => ''
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId');
$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}}/projects/:projectId/datasets/:datasetId/models/:modelId' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "bestTrialId": "",
  "creationTime": "",
  "defaultTrialId": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "featureColumns": [
    {
      "name": "",
      "type": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      }
    }
  ],
  "friendlyName": "",
  "hparamSearchSpaces": {
    "activationFn": {
      "candidates": []
    },
    "batchSize": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "boosterType": {},
    "colsampleBylevel": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "colsampleBynode": {},
    "colsampleBytree": {},
    "dartNormalizeType": {},
    "dropout": {},
    "hiddenUnits": {
      "candidates": [
        {
          "elements": []
        }
      ]
    },
    "l1Reg": {},
    "l2Reg": {},
    "learnRate": {},
    "maxTreeDepth": {},
    "minSplitLoss": {},
    "minTreeChildWeight": {},
    "numClusters": {},
    "numFactors": {},
    "numParallelTree": {},
    "optimizer": {},
    "subsample": {},
    "treeMethod": {},
    "walsAlpha": {}
  },
  "hparamTrials": [
    {
      "endTimeMs": "",
      "errorMessage": "",
      "evalLoss": "",
      "evaluationMetrics": {
        "arimaForecastingMetrics": {
          "arimaFittingMetrics": [
            {
              "aic": "",
              "logLikelihood": "",
              "variance": ""
            }
          ],
          "arimaSingleModelForecastingMetrics": [
            {
              "arimaFittingMetrics": {},
              "hasDrift": false,
              "hasHolidayEffect": false,
              "hasSpikesAndDips": false,
              "hasStepChanges": false,
              "nonSeasonalOrder": {
                "d": "",
                "p": "",
                "q": ""
              },
              "seasonalPeriods": [],
              "timeSeriesId": "",
              "timeSeriesIds": []
            }
          ],
          "hasDrift": [],
          "nonSeasonalOrder": [
            {}
          ],
          "seasonalPeriods": [],
          "timeSeriesId": []
        },
        "binaryClassificationMetrics": {
          "aggregateClassificationMetrics": {
            "accuracy": "",
            "f1Score": "",
            "logLoss": "",
            "precision": "",
            "recall": "",
            "rocAuc": "",
            "threshold": ""
          },
          "binaryConfusionMatrixList": [
            {
              "accuracy": "",
              "f1Score": "",
              "falseNegatives": "",
              "falsePositives": "",
              "positiveClassThreshold": "",
              "precision": "",
              "recall": "",
              "trueNegatives": "",
              "truePositives": ""
            }
          ],
          "negativeLabel": "",
          "positiveLabel": ""
        },
        "clusteringMetrics": {
          "clusters": [
            {
              "centroidId": "",
              "count": "",
              "featureValues": [
                {
                  "categoricalValue": {
                    "categoryCounts": [
                      {
                        "category": "",
                        "count": ""
                      }
                    ]
                  },
                  "featureColumn": "",
                  "numericalValue": ""
                }
              ]
            }
          ],
          "daviesBouldinIndex": "",
          "meanSquaredDistance": ""
        },
        "dimensionalityReductionMetrics": {
          "totalExplainedVarianceRatio": ""
        },
        "multiClassClassificationMetrics": {
          "aggregateClassificationMetrics": {},
          "confusionMatrixList": [
            {
              "confidenceThreshold": "",
              "rows": [
                {
                  "actualLabel": "",
                  "entries": [
                    {
                      "itemCount": "",
                      "predictedLabel": ""
                    }
                  ]
                }
              ]
            }
          ]
        },
        "rankingMetrics": {
          "averageRank": "",
          "meanAveragePrecision": "",
          "meanSquaredError": "",
          "normalizedDiscountedCumulativeGain": ""
        },
        "regressionMetrics": {
          "meanAbsoluteError": "",
          "meanSquaredError": "",
          "meanSquaredLogError": "",
          "medianAbsoluteError": "",
          "rSquared": ""
        }
      },
      "hparamTuningEvaluationMetrics": {},
      "hparams": {
        "adjustStepChanges": false,
        "autoArima": false,
        "autoArimaMaxOrder": "",
        "autoArimaMinOrder": "",
        "batchSize": "",
        "boosterType": "",
        "calculatePValues": false,
        "cleanSpikesAndDips": false,
        "colorSpace": "",
        "colsampleBylevel": "",
        "colsampleBynode": "",
        "colsampleBytree": "",
        "dartNormalizeType": "",
        "dataFrequency": "",
        "dataSplitColumn": "",
        "dataSplitEvalFraction": "",
        "dataSplitMethod": "",
        "decomposeTimeSeries": false,
        "distanceType": "",
        "dropout": "",
        "earlyStop": false,
        "enableGlobalExplain": false,
        "feedbackType": "",
        "hiddenUnits": [],
        "holidayRegion": "",
        "horizon": "",
        "hparamTuningObjectives": [],
        "includeDrift": false,
        "initialLearnRate": "",
        "inputLabelColumns": [],
        "integratedGradientsNumSteps": "",
        "itemColumn": "",
        "kmeansInitializationColumn": "",
        "kmeansInitializationMethod": "",
        "l1Regularization": "",
        "l2Regularization": "",
        "labelClassWeights": {},
        "learnRate": "",
        "learnRateStrategy": "",
        "lossType": "",
        "maxIterations": "",
        "maxParallelTrials": "",
        "maxTimeSeriesLength": "",
        "maxTreeDepth": "",
        "minRelativeProgress": "",
        "minSplitLoss": "",
        "minTimeSeriesLength": "",
        "minTreeChildWeight": "",
        "modelUri": "",
        "nonSeasonalOrder": {},
        "numClusters": "",
        "numFactors": "",
        "numParallelTree": "",
        "numTrials": "",
        "optimizationStrategy": "",
        "preserveInputStructs": false,
        "sampledShapleyNumPaths": "",
        "subsample": "",
        "timeSeriesDataColumn": "",
        "timeSeriesIdColumn": "",
        "timeSeriesIdColumns": [],
        "timeSeriesLengthFraction": "",
        "timeSeriesTimestampColumn": "",
        "treeMethod": "",
        "trendSmoothingWindowSize": "",
        "userColumn": "",
        "walsAlpha": "",
        "warmStart": false
      },
      "startTimeMs": "",
      "status": "",
      "trainingLoss": "",
      "trialId": ""
    }
  ],
  "labelColumns": [
    {}
  ],
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "modelReference": {
    "datasetId": "",
    "modelId": "",
    "projectId": ""
  },
  "modelType": "",
  "optimalTrialIds": [],
  "trainingRuns": [
    {
      "classLevelGlobalExplanations": [
        {
          "classLabel": "",
          "explanations": [
            {
              "attribution": "",
              "featureName": ""
            }
          ]
        }
      ],
      "dataSplitResult": {
        "evaluationTable": {
          "datasetId": "",
          "projectId": "",
          "tableId": ""
        },
        "testTable": {},
        "trainingTable": {}
      },
      "evaluationMetrics": {},
      "modelLevelGlobalExplanation": {},
      "results": [
        {
          "durationMs": "",
          "evalLoss": "",
          "index": 0,
          "learnRate": "",
          "trainingLoss": ""
        }
      ],
      "startTime": "",
      "trainingOptions": {},
      "trainingStartTime": "",
      "vertexAiModelId": "",
      "vertexAiModelVersion": ""
    }
  ]
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "bestTrialId": "",
  "creationTime": "",
  "defaultTrialId": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "featureColumns": [
    {
      "name": "",
      "type": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      }
    }
  ],
  "friendlyName": "",
  "hparamSearchSpaces": {
    "activationFn": {
      "candidates": []
    },
    "batchSize": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "boosterType": {},
    "colsampleBylevel": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "colsampleBynode": {},
    "colsampleBytree": {},
    "dartNormalizeType": {},
    "dropout": {},
    "hiddenUnits": {
      "candidates": [
        {
          "elements": []
        }
      ]
    },
    "l1Reg": {},
    "l2Reg": {},
    "learnRate": {},
    "maxTreeDepth": {},
    "minSplitLoss": {},
    "minTreeChildWeight": {},
    "numClusters": {},
    "numFactors": {},
    "numParallelTree": {},
    "optimizer": {},
    "subsample": {},
    "treeMethod": {},
    "walsAlpha": {}
  },
  "hparamTrials": [
    {
      "endTimeMs": "",
      "errorMessage": "",
      "evalLoss": "",
      "evaluationMetrics": {
        "arimaForecastingMetrics": {
          "arimaFittingMetrics": [
            {
              "aic": "",
              "logLikelihood": "",
              "variance": ""
            }
          ],
          "arimaSingleModelForecastingMetrics": [
            {
              "arimaFittingMetrics": {},
              "hasDrift": false,
              "hasHolidayEffect": false,
              "hasSpikesAndDips": false,
              "hasStepChanges": false,
              "nonSeasonalOrder": {
                "d": "",
                "p": "",
                "q": ""
              },
              "seasonalPeriods": [],
              "timeSeriesId": "",
              "timeSeriesIds": []
            }
          ],
          "hasDrift": [],
          "nonSeasonalOrder": [
            {}
          ],
          "seasonalPeriods": [],
          "timeSeriesId": []
        },
        "binaryClassificationMetrics": {
          "aggregateClassificationMetrics": {
            "accuracy": "",
            "f1Score": "",
            "logLoss": "",
            "precision": "",
            "recall": "",
            "rocAuc": "",
            "threshold": ""
          },
          "binaryConfusionMatrixList": [
            {
              "accuracy": "",
              "f1Score": "",
              "falseNegatives": "",
              "falsePositives": "",
              "positiveClassThreshold": "",
              "precision": "",
              "recall": "",
              "trueNegatives": "",
              "truePositives": ""
            }
          ],
          "negativeLabel": "",
          "positiveLabel": ""
        },
        "clusteringMetrics": {
          "clusters": [
            {
              "centroidId": "",
              "count": "",
              "featureValues": [
                {
                  "categoricalValue": {
                    "categoryCounts": [
                      {
                        "category": "",
                        "count": ""
                      }
                    ]
                  },
                  "featureColumn": "",
                  "numericalValue": ""
                }
              ]
            }
          ],
          "daviesBouldinIndex": "",
          "meanSquaredDistance": ""
        },
        "dimensionalityReductionMetrics": {
          "totalExplainedVarianceRatio": ""
        },
        "multiClassClassificationMetrics": {
          "aggregateClassificationMetrics": {},
          "confusionMatrixList": [
            {
              "confidenceThreshold": "",
              "rows": [
                {
                  "actualLabel": "",
                  "entries": [
                    {
                      "itemCount": "",
                      "predictedLabel": ""
                    }
                  ]
                }
              ]
            }
          ]
        },
        "rankingMetrics": {
          "averageRank": "",
          "meanAveragePrecision": "",
          "meanSquaredError": "",
          "normalizedDiscountedCumulativeGain": ""
        },
        "regressionMetrics": {
          "meanAbsoluteError": "",
          "meanSquaredError": "",
          "meanSquaredLogError": "",
          "medianAbsoluteError": "",
          "rSquared": ""
        }
      },
      "hparamTuningEvaluationMetrics": {},
      "hparams": {
        "adjustStepChanges": false,
        "autoArima": false,
        "autoArimaMaxOrder": "",
        "autoArimaMinOrder": "",
        "batchSize": "",
        "boosterType": "",
        "calculatePValues": false,
        "cleanSpikesAndDips": false,
        "colorSpace": "",
        "colsampleBylevel": "",
        "colsampleBynode": "",
        "colsampleBytree": "",
        "dartNormalizeType": "",
        "dataFrequency": "",
        "dataSplitColumn": "",
        "dataSplitEvalFraction": "",
        "dataSplitMethod": "",
        "decomposeTimeSeries": false,
        "distanceType": "",
        "dropout": "",
        "earlyStop": false,
        "enableGlobalExplain": false,
        "feedbackType": "",
        "hiddenUnits": [],
        "holidayRegion": "",
        "horizon": "",
        "hparamTuningObjectives": [],
        "includeDrift": false,
        "initialLearnRate": "",
        "inputLabelColumns": [],
        "integratedGradientsNumSteps": "",
        "itemColumn": "",
        "kmeansInitializationColumn": "",
        "kmeansInitializationMethod": "",
        "l1Regularization": "",
        "l2Regularization": "",
        "labelClassWeights": {},
        "learnRate": "",
        "learnRateStrategy": "",
        "lossType": "",
        "maxIterations": "",
        "maxParallelTrials": "",
        "maxTimeSeriesLength": "",
        "maxTreeDepth": "",
        "minRelativeProgress": "",
        "minSplitLoss": "",
        "minTimeSeriesLength": "",
        "minTreeChildWeight": "",
        "modelUri": "",
        "nonSeasonalOrder": {},
        "numClusters": "",
        "numFactors": "",
        "numParallelTree": "",
        "numTrials": "",
        "optimizationStrategy": "",
        "preserveInputStructs": false,
        "sampledShapleyNumPaths": "",
        "subsample": "",
        "timeSeriesDataColumn": "",
        "timeSeriesIdColumn": "",
        "timeSeriesIdColumns": [],
        "timeSeriesLengthFraction": "",
        "timeSeriesTimestampColumn": "",
        "treeMethod": "",
        "trendSmoothingWindowSize": "",
        "userColumn": "",
        "walsAlpha": "",
        "warmStart": false
      },
      "startTimeMs": "",
      "status": "",
      "trainingLoss": "",
      "trialId": ""
    }
  ],
  "labelColumns": [
    {}
  ],
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "modelReference": {
    "datasetId": "",
    "modelId": "",
    "projectId": ""
  },
  "modelType": "",
  "optimalTrialIds": [],
  "trainingRuns": [
    {
      "classLevelGlobalExplanations": [
        {
          "classLabel": "",
          "explanations": [
            {
              "attribution": "",
              "featureName": ""
            }
          ]
        }
      ],
      "dataSplitResult": {
        "evaluationTable": {
          "datasetId": "",
          "projectId": "",
          "tableId": ""
        },
        "testTable": {},
        "trainingTable": {}
      },
      "evaluationMetrics": {},
      "modelLevelGlobalExplanation": {},
      "results": [
        {
          "durationMs": "",
          "evalLoss": "",
          "index": 0,
          "learnRate": "",
          "trainingLoss": ""
        }
      ],
      "startTime": "",
      "trainingOptions": {},
      "trainingStartTime": "",
      "vertexAiModelId": "",
      "vertexAiModelVersion": ""
    }
  ]
}'
import http.client

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

payload = "{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\n}"

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

conn.request("PATCH", "/baseUrl/projects/:projectId/datasets/:datasetId/models/:modelId", payload, headers)

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"

payload = {
    "bestTrialId": "",
    "creationTime": "",
    "defaultTrialId": "",
    "description": "",
    "encryptionConfiguration": { "kmsKeyName": "" },
    "etag": "",
    "expirationTime": "",
    "featureColumns": [
        {
            "name": "",
            "type": {
                "arrayElementType": "",
                "structType": { "fields": [] },
                "typeKind": ""
            }
        }
    ],
    "friendlyName": "",
    "hparamSearchSpaces": {
        "activationFn": { "candidates": [] },
        "batchSize": {
            "candidates": { "candidates": [] },
            "range": {
                "max": "",
                "min": ""
            }
        },
        "boosterType": {},
        "colsampleBylevel": {
            "candidates": { "candidates": [] },
            "range": {
                "max": "",
                "min": ""
            }
        },
        "colsampleBynode": {},
        "colsampleBytree": {},
        "dartNormalizeType": {},
        "dropout": {},
        "hiddenUnits": { "candidates": [{ "elements": [] }] },
        "l1Reg": {},
        "l2Reg": {},
        "learnRate": {},
        "maxTreeDepth": {},
        "minSplitLoss": {},
        "minTreeChildWeight": {},
        "numClusters": {},
        "numFactors": {},
        "numParallelTree": {},
        "optimizer": {},
        "subsample": {},
        "treeMethod": {},
        "walsAlpha": {}
    },
    "hparamTrials": [
        {
            "endTimeMs": "",
            "errorMessage": "",
            "evalLoss": "",
            "evaluationMetrics": {
                "arimaForecastingMetrics": {
                    "arimaFittingMetrics": [
                        {
                            "aic": "",
                            "logLikelihood": "",
                            "variance": ""
                        }
                    ],
                    "arimaSingleModelForecastingMetrics": [
                        {
                            "arimaFittingMetrics": {},
                            "hasDrift": False,
                            "hasHolidayEffect": False,
                            "hasSpikesAndDips": False,
                            "hasStepChanges": False,
                            "nonSeasonalOrder": {
                                "d": "",
                                "p": "",
                                "q": ""
                            },
                            "seasonalPeriods": [],
                            "timeSeriesId": "",
                            "timeSeriesIds": []
                        }
                    ],
                    "hasDrift": [],
                    "nonSeasonalOrder": [{}],
                    "seasonalPeriods": [],
                    "timeSeriesId": []
                },
                "binaryClassificationMetrics": {
                    "aggregateClassificationMetrics": {
                        "accuracy": "",
                        "f1Score": "",
                        "logLoss": "",
                        "precision": "",
                        "recall": "",
                        "rocAuc": "",
                        "threshold": ""
                    },
                    "binaryConfusionMatrixList": [
                        {
                            "accuracy": "",
                            "f1Score": "",
                            "falseNegatives": "",
                            "falsePositives": "",
                            "positiveClassThreshold": "",
                            "precision": "",
                            "recall": "",
                            "trueNegatives": "",
                            "truePositives": ""
                        }
                    ],
                    "negativeLabel": "",
                    "positiveLabel": ""
                },
                "clusteringMetrics": {
                    "clusters": [
                        {
                            "centroidId": "",
                            "count": "",
                            "featureValues": [
                                {
                                    "categoricalValue": { "categoryCounts": [
                                            {
                                                "category": "",
                                                "count": ""
                                            }
                                        ] },
                                    "featureColumn": "",
                                    "numericalValue": ""
                                }
                            ]
                        }
                    ],
                    "daviesBouldinIndex": "",
                    "meanSquaredDistance": ""
                },
                "dimensionalityReductionMetrics": { "totalExplainedVarianceRatio": "" },
                "multiClassClassificationMetrics": {
                    "aggregateClassificationMetrics": {},
                    "confusionMatrixList": [
                        {
                            "confidenceThreshold": "",
                            "rows": [
                                {
                                    "actualLabel": "",
                                    "entries": [
                                        {
                                            "itemCount": "",
                                            "predictedLabel": ""
                                        }
                                    ]
                                }
                            ]
                        }
                    ]
                },
                "rankingMetrics": {
                    "averageRank": "",
                    "meanAveragePrecision": "",
                    "meanSquaredError": "",
                    "normalizedDiscountedCumulativeGain": ""
                },
                "regressionMetrics": {
                    "meanAbsoluteError": "",
                    "meanSquaredError": "",
                    "meanSquaredLogError": "",
                    "medianAbsoluteError": "",
                    "rSquared": ""
                }
            },
            "hparamTuningEvaluationMetrics": {},
            "hparams": {
                "adjustStepChanges": False,
                "autoArima": False,
                "autoArimaMaxOrder": "",
                "autoArimaMinOrder": "",
                "batchSize": "",
                "boosterType": "",
                "calculatePValues": False,
                "cleanSpikesAndDips": False,
                "colorSpace": "",
                "colsampleBylevel": "",
                "colsampleBynode": "",
                "colsampleBytree": "",
                "dartNormalizeType": "",
                "dataFrequency": "",
                "dataSplitColumn": "",
                "dataSplitEvalFraction": "",
                "dataSplitMethod": "",
                "decomposeTimeSeries": False,
                "distanceType": "",
                "dropout": "",
                "earlyStop": False,
                "enableGlobalExplain": False,
                "feedbackType": "",
                "hiddenUnits": [],
                "holidayRegion": "",
                "horizon": "",
                "hparamTuningObjectives": [],
                "includeDrift": False,
                "initialLearnRate": "",
                "inputLabelColumns": [],
                "integratedGradientsNumSteps": "",
                "itemColumn": "",
                "kmeansInitializationColumn": "",
                "kmeansInitializationMethod": "",
                "l1Regularization": "",
                "l2Regularization": "",
                "labelClassWeights": {},
                "learnRate": "",
                "learnRateStrategy": "",
                "lossType": "",
                "maxIterations": "",
                "maxParallelTrials": "",
                "maxTimeSeriesLength": "",
                "maxTreeDepth": "",
                "minRelativeProgress": "",
                "minSplitLoss": "",
                "minTimeSeriesLength": "",
                "minTreeChildWeight": "",
                "modelUri": "",
                "nonSeasonalOrder": {},
                "numClusters": "",
                "numFactors": "",
                "numParallelTree": "",
                "numTrials": "",
                "optimizationStrategy": "",
                "preserveInputStructs": False,
                "sampledShapleyNumPaths": "",
                "subsample": "",
                "timeSeriesDataColumn": "",
                "timeSeriesIdColumn": "",
                "timeSeriesIdColumns": [],
                "timeSeriesLengthFraction": "",
                "timeSeriesTimestampColumn": "",
                "treeMethod": "",
                "trendSmoothingWindowSize": "",
                "userColumn": "",
                "walsAlpha": "",
                "warmStart": False
            },
            "startTimeMs": "",
            "status": "",
            "trainingLoss": "",
            "trialId": ""
        }
    ],
    "labelColumns": [{}],
    "labels": {},
    "lastModifiedTime": "",
    "location": "",
    "modelReference": {
        "datasetId": "",
        "modelId": "",
        "projectId": ""
    },
    "modelType": "",
    "optimalTrialIds": [],
    "trainingRuns": [
        {
            "classLevelGlobalExplanations": [
                {
                    "classLabel": "",
                    "explanations": [
                        {
                            "attribution": "",
                            "featureName": ""
                        }
                    ]
                }
            ],
            "dataSplitResult": {
                "evaluationTable": {
                    "datasetId": "",
                    "projectId": "",
                    "tableId": ""
                },
                "testTable": {},
                "trainingTable": {}
            },
            "evaluationMetrics": {},
            "modelLevelGlobalExplanation": {},
            "results": [
                {
                    "durationMs": "",
                    "evalLoss": "",
                    "index": 0,
                    "learnRate": "",
                    "trainingLoss": ""
                }
            ],
            "startTime": "",
            "trainingOptions": {},
            "trainingStartTime": "",
            "vertexAiModelId": "",
            "vertexAiModelVersion": ""
        }
    ]
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId"

payload <- "{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\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}}/projects/:projectId/datasets/:datasetId/models/:modelId")

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  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\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.patch('/baseUrl/projects/:projectId/datasets/:datasetId/models/:modelId') do |req|
  req.body = "{\n  \"bestTrialId\": \"\",\n  \"creationTime\": \"\",\n  \"defaultTrialId\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"featureColumns\": [\n    {\n      \"name\": \"\",\n      \"type\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      }\n    }\n  ],\n  \"friendlyName\": \"\",\n  \"hparamSearchSpaces\": {\n    \"activationFn\": {\n      \"candidates\": []\n    },\n    \"batchSize\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"boosterType\": {},\n    \"colsampleBylevel\": {\n      \"candidates\": {\n        \"candidates\": []\n      },\n      \"range\": {\n        \"max\": \"\",\n        \"min\": \"\"\n      }\n    },\n    \"colsampleBynode\": {},\n    \"colsampleBytree\": {},\n    \"dartNormalizeType\": {},\n    \"dropout\": {},\n    \"hiddenUnits\": {\n      \"candidates\": [\n        {\n          \"elements\": []\n        }\n      ]\n    },\n    \"l1Reg\": {},\n    \"l2Reg\": {},\n    \"learnRate\": {},\n    \"maxTreeDepth\": {},\n    \"minSplitLoss\": {},\n    \"minTreeChildWeight\": {},\n    \"numClusters\": {},\n    \"numFactors\": {},\n    \"numParallelTree\": {},\n    \"optimizer\": {},\n    \"subsample\": {},\n    \"treeMethod\": {},\n    \"walsAlpha\": {}\n  },\n  \"hparamTrials\": [\n    {\n      \"endTimeMs\": \"\",\n      \"errorMessage\": \"\",\n      \"evalLoss\": \"\",\n      \"evaluationMetrics\": {\n        \"arimaForecastingMetrics\": {\n          \"arimaFittingMetrics\": [\n            {\n              \"aic\": \"\",\n              \"logLikelihood\": \"\",\n              \"variance\": \"\"\n            }\n          ],\n          \"arimaSingleModelForecastingMetrics\": [\n            {\n              \"arimaFittingMetrics\": {},\n              \"hasDrift\": false,\n              \"hasHolidayEffect\": false,\n              \"hasSpikesAndDips\": false,\n              \"hasStepChanges\": false,\n              \"nonSeasonalOrder\": {\n                \"d\": \"\",\n                \"p\": \"\",\n                \"q\": \"\"\n              },\n              \"seasonalPeriods\": [],\n              \"timeSeriesId\": \"\",\n              \"timeSeriesIds\": []\n            }\n          ],\n          \"hasDrift\": [],\n          \"nonSeasonalOrder\": [\n            {}\n          ],\n          \"seasonalPeriods\": [],\n          \"timeSeriesId\": []\n        },\n        \"binaryClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {\n            \"accuracy\": \"\",\n            \"f1Score\": \"\",\n            \"logLoss\": \"\",\n            \"precision\": \"\",\n            \"recall\": \"\",\n            \"rocAuc\": \"\",\n            \"threshold\": \"\"\n          },\n          \"binaryConfusionMatrixList\": [\n            {\n              \"accuracy\": \"\",\n              \"f1Score\": \"\",\n              \"falseNegatives\": \"\",\n              \"falsePositives\": \"\",\n              \"positiveClassThreshold\": \"\",\n              \"precision\": \"\",\n              \"recall\": \"\",\n              \"trueNegatives\": \"\",\n              \"truePositives\": \"\"\n            }\n          ],\n          \"negativeLabel\": \"\",\n          \"positiveLabel\": \"\"\n        },\n        \"clusteringMetrics\": {\n          \"clusters\": [\n            {\n              \"centroidId\": \"\",\n              \"count\": \"\",\n              \"featureValues\": [\n                {\n                  \"categoricalValue\": {\n                    \"categoryCounts\": [\n                      {\n                        \"category\": \"\",\n                        \"count\": \"\"\n                      }\n                    ]\n                  },\n                  \"featureColumn\": \"\",\n                  \"numericalValue\": \"\"\n                }\n              ]\n            }\n          ],\n          \"daviesBouldinIndex\": \"\",\n          \"meanSquaredDistance\": \"\"\n        },\n        \"dimensionalityReductionMetrics\": {\n          \"totalExplainedVarianceRatio\": \"\"\n        },\n        \"multiClassClassificationMetrics\": {\n          \"aggregateClassificationMetrics\": {},\n          \"confusionMatrixList\": [\n            {\n              \"confidenceThreshold\": \"\",\n              \"rows\": [\n                {\n                  \"actualLabel\": \"\",\n                  \"entries\": [\n                    {\n                      \"itemCount\": \"\",\n                      \"predictedLabel\": \"\"\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        \"rankingMetrics\": {\n          \"averageRank\": \"\",\n          \"meanAveragePrecision\": \"\",\n          \"meanSquaredError\": \"\",\n          \"normalizedDiscountedCumulativeGain\": \"\"\n        },\n        \"regressionMetrics\": {\n          \"meanAbsoluteError\": \"\",\n          \"meanSquaredError\": \"\",\n          \"meanSquaredLogError\": \"\",\n          \"medianAbsoluteError\": \"\",\n          \"rSquared\": \"\"\n        }\n      },\n      \"hparamTuningEvaluationMetrics\": {},\n      \"hparams\": {\n        \"adjustStepChanges\": false,\n        \"autoArima\": false,\n        \"autoArimaMaxOrder\": \"\",\n        \"autoArimaMinOrder\": \"\",\n        \"batchSize\": \"\",\n        \"boosterType\": \"\",\n        \"calculatePValues\": false,\n        \"cleanSpikesAndDips\": false,\n        \"colorSpace\": \"\",\n        \"colsampleBylevel\": \"\",\n        \"colsampleBynode\": \"\",\n        \"colsampleBytree\": \"\",\n        \"dartNormalizeType\": \"\",\n        \"dataFrequency\": \"\",\n        \"dataSplitColumn\": \"\",\n        \"dataSplitEvalFraction\": \"\",\n        \"dataSplitMethod\": \"\",\n        \"decomposeTimeSeries\": false,\n        \"distanceType\": \"\",\n        \"dropout\": \"\",\n        \"earlyStop\": false,\n        \"enableGlobalExplain\": false,\n        \"feedbackType\": \"\",\n        \"hiddenUnits\": [],\n        \"holidayRegion\": \"\",\n        \"horizon\": \"\",\n        \"hparamTuningObjectives\": [],\n        \"includeDrift\": false,\n        \"initialLearnRate\": \"\",\n        \"inputLabelColumns\": [],\n        \"integratedGradientsNumSteps\": \"\",\n        \"itemColumn\": \"\",\n        \"kmeansInitializationColumn\": \"\",\n        \"kmeansInitializationMethod\": \"\",\n        \"l1Regularization\": \"\",\n        \"l2Regularization\": \"\",\n        \"labelClassWeights\": {},\n        \"learnRate\": \"\",\n        \"learnRateStrategy\": \"\",\n        \"lossType\": \"\",\n        \"maxIterations\": \"\",\n        \"maxParallelTrials\": \"\",\n        \"maxTimeSeriesLength\": \"\",\n        \"maxTreeDepth\": \"\",\n        \"minRelativeProgress\": \"\",\n        \"minSplitLoss\": \"\",\n        \"minTimeSeriesLength\": \"\",\n        \"minTreeChildWeight\": \"\",\n        \"modelUri\": \"\",\n        \"nonSeasonalOrder\": {},\n        \"numClusters\": \"\",\n        \"numFactors\": \"\",\n        \"numParallelTree\": \"\",\n        \"numTrials\": \"\",\n        \"optimizationStrategy\": \"\",\n        \"preserveInputStructs\": false,\n        \"sampledShapleyNumPaths\": \"\",\n        \"subsample\": \"\",\n        \"timeSeriesDataColumn\": \"\",\n        \"timeSeriesIdColumn\": \"\",\n        \"timeSeriesIdColumns\": [],\n        \"timeSeriesLengthFraction\": \"\",\n        \"timeSeriesTimestampColumn\": \"\",\n        \"treeMethod\": \"\",\n        \"trendSmoothingWindowSize\": \"\",\n        \"userColumn\": \"\",\n        \"walsAlpha\": \"\",\n        \"warmStart\": false\n      },\n      \"startTimeMs\": \"\",\n      \"status\": \"\",\n      \"trainingLoss\": \"\",\n      \"trialId\": \"\"\n    }\n  ],\n  \"labelColumns\": [\n    {}\n  ],\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"modelReference\": {\n    \"datasetId\": \"\",\n    \"modelId\": \"\",\n    \"projectId\": \"\"\n  },\n  \"modelType\": \"\",\n  \"optimalTrialIds\": [],\n  \"trainingRuns\": [\n    {\n      \"classLevelGlobalExplanations\": [\n        {\n          \"classLabel\": \"\",\n          \"explanations\": [\n            {\n              \"attribution\": \"\",\n              \"featureName\": \"\"\n            }\n          ]\n        }\n      ],\n      \"dataSplitResult\": {\n        \"evaluationTable\": {\n          \"datasetId\": \"\",\n          \"projectId\": \"\",\n          \"tableId\": \"\"\n        },\n        \"testTable\": {},\n        \"trainingTable\": {}\n      },\n      \"evaluationMetrics\": {},\n      \"modelLevelGlobalExplanation\": {},\n      \"results\": [\n        {\n          \"durationMs\": \"\",\n          \"evalLoss\": \"\",\n          \"index\": 0,\n          \"learnRate\": \"\",\n          \"trainingLoss\": \"\"\n        }\n      ],\n      \"startTime\": \"\",\n      \"trainingOptions\": {},\n      \"trainingStartTime\": \"\",\n      \"vertexAiModelId\": \"\",\n      \"vertexAiModelVersion\": \"\"\n    }\n  ]\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId";

    let payload = json!({
        "bestTrialId": "",
        "creationTime": "",
        "defaultTrialId": "",
        "description": "",
        "encryptionConfiguration": json!({"kmsKeyName": ""}),
        "etag": "",
        "expirationTime": "",
        "featureColumns": (
            json!({
                "name": "",
                "type": json!({
                    "arrayElementType": "",
                    "structType": json!({"fields": ()}),
                    "typeKind": ""
                })
            })
        ),
        "friendlyName": "",
        "hparamSearchSpaces": json!({
            "activationFn": json!({"candidates": ()}),
            "batchSize": json!({
                "candidates": json!({"candidates": ()}),
                "range": json!({
                    "max": "",
                    "min": ""
                })
            }),
            "boosterType": json!({}),
            "colsampleBylevel": json!({
                "candidates": json!({"candidates": ()}),
                "range": json!({
                    "max": "",
                    "min": ""
                })
            }),
            "colsampleBynode": json!({}),
            "colsampleBytree": json!({}),
            "dartNormalizeType": json!({}),
            "dropout": json!({}),
            "hiddenUnits": json!({"candidates": (json!({"elements": ()}))}),
            "l1Reg": json!({}),
            "l2Reg": json!({}),
            "learnRate": json!({}),
            "maxTreeDepth": json!({}),
            "minSplitLoss": json!({}),
            "minTreeChildWeight": json!({}),
            "numClusters": json!({}),
            "numFactors": json!({}),
            "numParallelTree": json!({}),
            "optimizer": json!({}),
            "subsample": json!({}),
            "treeMethod": json!({}),
            "walsAlpha": json!({})
        }),
        "hparamTrials": (
            json!({
                "endTimeMs": "",
                "errorMessage": "",
                "evalLoss": "",
                "evaluationMetrics": json!({
                    "arimaForecastingMetrics": json!({
                        "arimaFittingMetrics": (
                            json!({
                                "aic": "",
                                "logLikelihood": "",
                                "variance": ""
                            })
                        ),
                        "arimaSingleModelForecastingMetrics": (
                            json!({
                                "arimaFittingMetrics": json!({}),
                                "hasDrift": false,
                                "hasHolidayEffect": false,
                                "hasSpikesAndDips": false,
                                "hasStepChanges": false,
                                "nonSeasonalOrder": json!({
                                    "d": "",
                                    "p": "",
                                    "q": ""
                                }),
                                "seasonalPeriods": (),
                                "timeSeriesId": "",
                                "timeSeriesIds": ()
                            })
                        ),
                        "hasDrift": (),
                        "nonSeasonalOrder": (json!({})),
                        "seasonalPeriods": (),
                        "timeSeriesId": ()
                    }),
                    "binaryClassificationMetrics": json!({
                        "aggregateClassificationMetrics": json!({
                            "accuracy": "",
                            "f1Score": "",
                            "logLoss": "",
                            "precision": "",
                            "recall": "",
                            "rocAuc": "",
                            "threshold": ""
                        }),
                        "binaryConfusionMatrixList": (
                            json!({
                                "accuracy": "",
                                "f1Score": "",
                                "falseNegatives": "",
                                "falsePositives": "",
                                "positiveClassThreshold": "",
                                "precision": "",
                                "recall": "",
                                "trueNegatives": "",
                                "truePositives": ""
                            })
                        ),
                        "negativeLabel": "",
                        "positiveLabel": ""
                    }),
                    "clusteringMetrics": json!({
                        "clusters": (
                            json!({
                                "centroidId": "",
                                "count": "",
                                "featureValues": (
                                    json!({
                                        "categoricalValue": json!({"categoryCounts": (
                                                json!({
                                                    "category": "",
                                                    "count": ""
                                                })
                                            )}),
                                        "featureColumn": "",
                                        "numericalValue": ""
                                    })
                                )
                            })
                        ),
                        "daviesBouldinIndex": "",
                        "meanSquaredDistance": ""
                    }),
                    "dimensionalityReductionMetrics": json!({"totalExplainedVarianceRatio": ""}),
                    "multiClassClassificationMetrics": json!({
                        "aggregateClassificationMetrics": json!({}),
                        "confusionMatrixList": (
                            json!({
                                "confidenceThreshold": "",
                                "rows": (
                                    json!({
                                        "actualLabel": "",
                                        "entries": (
                                            json!({
                                                "itemCount": "",
                                                "predictedLabel": ""
                                            })
                                        )
                                    })
                                )
                            })
                        )
                    }),
                    "rankingMetrics": json!({
                        "averageRank": "",
                        "meanAveragePrecision": "",
                        "meanSquaredError": "",
                        "normalizedDiscountedCumulativeGain": ""
                    }),
                    "regressionMetrics": json!({
                        "meanAbsoluteError": "",
                        "meanSquaredError": "",
                        "meanSquaredLogError": "",
                        "medianAbsoluteError": "",
                        "rSquared": ""
                    })
                }),
                "hparamTuningEvaluationMetrics": json!({}),
                "hparams": json!({
                    "adjustStepChanges": false,
                    "autoArima": false,
                    "autoArimaMaxOrder": "",
                    "autoArimaMinOrder": "",
                    "batchSize": "",
                    "boosterType": "",
                    "calculatePValues": false,
                    "cleanSpikesAndDips": false,
                    "colorSpace": "",
                    "colsampleBylevel": "",
                    "colsampleBynode": "",
                    "colsampleBytree": "",
                    "dartNormalizeType": "",
                    "dataFrequency": "",
                    "dataSplitColumn": "",
                    "dataSplitEvalFraction": "",
                    "dataSplitMethod": "",
                    "decomposeTimeSeries": false,
                    "distanceType": "",
                    "dropout": "",
                    "earlyStop": false,
                    "enableGlobalExplain": false,
                    "feedbackType": "",
                    "hiddenUnits": (),
                    "holidayRegion": "",
                    "horizon": "",
                    "hparamTuningObjectives": (),
                    "includeDrift": false,
                    "initialLearnRate": "",
                    "inputLabelColumns": (),
                    "integratedGradientsNumSteps": "",
                    "itemColumn": "",
                    "kmeansInitializationColumn": "",
                    "kmeansInitializationMethod": "",
                    "l1Regularization": "",
                    "l2Regularization": "",
                    "labelClassWeights": json!({}),
                    "learnRate": "",
                    "learnRateStrategy": "",
                    "lossType": "",
                    "maxIterations": "",
                    "maxParallelTrials": "",
                    "maxTimeSeriesLength": "",
                    "maxTreeDepth": "",
                    "minRelativeProgress": "",
                    "minSplitLoss": "",
                    "minTimeSeriesLength": "",
                    "minTreeChildWeight": "",
                    "modelUri": "",
                    "nonSeasonalOrder": json!({}),
                    "numClusters": "",
                    "numFactors": "",
                    "numParallelTree": "",
                    "numTrials": "",
                    "optimizationStrategy": "",
                    "preserveInputStructs": false,
                    "sampledShapleyNumPaths": "",
                    "subsample": "",
                    "timeSeriesDataColumn": "",
                    "timeSeriesIdColumn": "",
                    "timeSeriesIdColumns": (),
                    "timeSeriesLengthFraction": "",
                    "timeSeriesTimestampColumn": "",
                    "treeMethod": "",
                    "trendSmoothingWindowSize": "",
                    "userColumn": "",
                    "walsAlpha": "",
                    "warmStart": false
                }),
                "startTimeMs": "",
                "status": "",
                "trainingLoss": "",
                "trialId": ""
            })
        ),
        "labelColumns": (json!({})),
        "labels": json!({}),
        "lastModifiedTime": "",
        "location": "",
        "modelReference": json!({
            "datasetId": "",
            "modelId": "",
            "projectId": ""
        }),
        "modelType": "",
        "optimalTrialIds": (),
        "trainingRuns": (
            json!({
                "classLevelGlobalExplanations": (
                    json!({
                        "classLabel": "",
                        "explanations": (
                            json!({
                                "attribution": "",
                                "featureName": ""
                            })
                        )
                    })
                ),
                "dataSplitResult": json!({
                    "evaluationTable": json!({
                        "datasetId": "",
                        "projectId": "",
                        "tableId": ""
                    }),
                    "testTable": json!({}),
                    "trainingTable": json!({})
                }),
                "evaluationMetrics": json!({}),
                "modelLevelGlobalExplanation": json!({}),
                "results": (
                    json!({
                        "durationMs": "",
                        "evalLoss": "",
                        "index": 0,
                        "learnRate": "",
                        "trainingLoss": ""
                    })
                ),
                "startTime": "",
                "trainingOptions": json!({}),
                "trainingStartTime": "",
                "vertexAiModelId": "",
                "vertexAiModelVersion": ""
            })
        )
    });

    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}}/projects/:projectId/datasets/:datasetId/models/:modelId \
  --header 'content-type: application/json' \
  --data '{
  "bestTrialId": "",
  "creationTime": "",
  "defaultTrialId": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "featureColumns": [
    {
      "name": "",
      "type": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      }
    }
  ],
  "friendlyName": "",
  "hparamSearchSpaces": {
    "activationFn": {
      "candidates": []
    },
    "batchSize": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "boosterType": {},
    "colsampleBylevel": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "colsampleBynode": {},
    "colsampleBytree": {},
    "dartNormalizeType": {},
    "dropout": {},
    "hiddenUnits": {
      "candidates": [
        {
          "elements": []
        }
      ]
    },
    "l1Reg": {},
    "l2Reg": {},
    "learnRate": {},
    "maxTreeDepth": {},
    "minSplitLoss": {},
    "minTreeChildWeight": {},
    "numClusters": {},
    "numFactors": {},
    "numParallelTree": {},
    "optimizer": {},
    "subsample": {},
    "treeMethod": {},
    "walsAlpha": {}
  },
  "hparamTrials": [
    {
      "endTimeMs": "",
      "errorMessage": "",
      "evalLoss": "",
      "evaluationMetrics": {
        "arimaForecastingMetrics": {
          "arimaFittingMetrics": [
            {
              "aic": "",
              "logLikelihood": "",
              "variance": ""
            }
          ],
          "arimaSingleModelForecastingMetrics": [
            {
              "arimaFittingMetrics": {},
              "hasDrift": false,
              "hasHolidayEffect": false,
              "hasSpikesAndDips": false,
              "hasStepChanges": false,
              "nonSeasonalOrder": {
                "d": "",
                "p": "",
                "q": ""
              },
              "seasonalPeriods": [],
              "timeSeriesId": "",
              "timeSeriesIds": []
            }
          ],
          "hasDrift": [],
          "nonSeasonalOrder": [
            {}
          ],
          "seasonalPeriods": [],
          "timeSeriesId": []
        },
        "binaryClassificationMetrics": {
          "aggregateClassificationMetrics": {
            "accuracy": "",
            "f1Score": "",
            "logLoss": "",
            "precision": "",
            "recall": "",
            "rocAuc": "",
            "threshold": ""
          },
          "binaryConfusionMatrixList": [
            {
              "accuracy": "",
              "f1Score": "",
              "falseNegatives": "",
              "falsePositives": "",
              "positiveClassThreshold": "",
              "precision": "",
              "recall": "",
              "trueNegatives": "",
              "truePositives": ""
            }
          ],
          "negativeLabel": "",
          "positiveLabel": ""
        },
        "clusteringMetrics": {
          "clusters": [
            {
              "centroidId": "",
              "count": "",
              "featureValues": [
                {
                  "categoricalValue": {
                    "categoryCounts": [
                      {
                        "category": "",
                        "count": ""
                      }
                    ]
                  },
                  "featureColumn": "",
                  "numericalValue": ""
                }
              ]
            }
          ],
          "daviesBouldinIndex": "",
          "meanSquaredDistance": ""
        },
        "dimensionalityReductionMetrics": {
          "totalExplainedVarianceRatio": ""
        },
        "multiClassClassificationMetrics": {
          "aggregateClassificationMetrics": {},
          "confusionMatrixList": [
            {
              "confidenceThreshold": "",
              "rows": [
                {
                  "actualLabel": "",
                  "entries": [
                    {
                      "itemCount": "",
                      "predictedLabel": ""
                    }
                  ]
                }
              ]
            }
          ]
        },
        "rankingMetrics": {
          "averageRank": "",
          "meanAveragePrecision": "",
          "meanSquaredError": "",
          "normalizedDiscountedCumulativeGain": ""
        },
        "regressionMetrics": {
          "meanAbsoluteError": "",
          "meanSquaredError": "",
          "meanSquaredLogError": "",
          "medianAbsoluteError": "",
          "rSquared": ""
        }
      },
      "hparamTuningEvaluationMetrics": {},
      "hparams": {
        "adjustStepChanges": false,
        "autoArima": false,
        "autoArimaMaxOrder": "",
        "autoArimaMinOrder": "",
        "batchSize": "",
        "boosterType": "",
        "calculatePValues": false,
        "cleanSpikesAndDips": false,
        "colorSpace": "",
        "colsampleBylevel": "",
        "colsampleBynode": "",
        "colsampleBytree": "",
        "dartNormalizeType": "",
        "dataFrequency": "",
        "dataSplitColumn": "",
        "dataSplitEvalFraction": "",
        "dataSplitMethod": "",
        "decomposeTimeSeries": false,
        "distanceType": "",
        "dropout": "",
        "earlyStop": false,
        "enableGlobalExplain": false,
        "feedbackType": "",
        "hiddenUnits": [],
        "holidayRegion": "",
        "horizon": "",
        "hparamTuningObjectives": [],
        "includeDrift": false,
        "initialLearnRate": "",
        "inputLabelColumns": [],
        "integratedGradientsNumSteps": "",
        "itemColumn": "",
        "kmeansInitializationColumn": "",
        "kmeansInitializationMethod": "",
        "l1Regularization": "",
        "l2Regularization": "",
        "labelClassWeights": {},
        "learnRate": "",
        "learnRateStrategy": "",
        "lossType": "",
        "maxIterations": "",
        "maxParallelTrials": "",
        "maxTimeSeriesLength": "",
        "maxTreeDepth": "",
        "minRelativeProgress": "",
        "minSplitLoss": "",
        "minTimeSeriesLength": "",
        "minTreeChildWeight": "",
        "modelUri": "",
        "nonSeasonalOrder": {},
        "numClusters": "",
        "numFactors": "",
        "numParallelTree": "",
        "numTrials": "",
        "optimizationStrategy": "",
        "preserveInputStructs": false,
        "sampledShapleyNumPaths": "",
        "subsample": "",
        "timeSeriesDataColumn": "",
        "timeSeriesIdColumn": "",
        "timeSeriesIdColumns": [],
        "timeSeriesLengthFraction": "",
        "timeSeriesTimestampColumn": "",
        "treeMethod": "",
        "trendSmoothingWindowSize": "",
        "userColumn": "",
        "walsAlpha": "",
        "warmStart": false
      },
      "startTimeMs": "",
      "status": "",
      "trainingLoss": "",
      "trialId": ""
    }
  ],
  "labelColumns": [
    {}
  ],
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "modelReference": {
    "datasetId": "",
    "modelId": "",
    "projectId": ""
  },
  "modelType": "",
  "optimalTrialIds": [],
  "trainingRuns": [
    {
      "classLevelGlobalExplanations": [
        {
          "classLabel": "",
          "explanations": [
            {
              "attribution": "",
              "featureName": ""
            }
          ]
        }
      ],
      "dataSplitResult": {
        "evaluationTable": {
          "datasetId": "",
          "projectId": "",
          "tableId": ""
        },
        "testTable": {},
        "trainingTable": {}
      },
      "evaluationMetrics": {},
      "modelLevelGlobalExplanation": {},
      "results": [
        {
          "durationMs": "",
          "evalLoss": "",
          "index": 0,
          "learnRate": "",
          "trainingLoss": ""
        }
      ],
      "startTime": "",
      "trainingOptions": {},
      "trainingStartTime": "",
      "vertexAiModelId": "",
      "vertexAiModelVersion": ""
    }
  ]
}'
echo '{
  "bestTrialId": "",
  "creationTime": "",
  "defaultTrialId": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "featureColumns": [
    {
      "name": "",
      "type": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      }
    }
  ],
  "friendlyName": "",
  "hparamSearchSpaces": {
    "activationFn": {
      "candidates": []
    },
    "batchSize": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "boosterType": {},
    "colsampleBylevel": {
      "candidates": {
        "candidates": []
      },
      "range": {
        "max": "",
        "min": ""
      }
    },
    "colsampleBynode": {},
    "colsampleBytree": {},
    "dartNormalizeType": {},
    "dropout": {},
    "hiddenUnits": {
      "candidates": [
        {
          "elements": []
        }
      ]
    },
    "l1Reg": {},
    "l2Reg": {},
    "learnRate": {},
    "maxTreeDepth": {},
    "minSplitLoss": {},
    "minTreeChildWeight": {},
    "numClusters": {},
    "numFactors": {},
    "numParallelTree": {},
    "optimizer": {},
    "subsample": {},
    "treeMethod": {},
    "walsAlpha": {}
  },
  "hparamTrials": [
    {
      "endTimeMs": "",
      "errorMessage": "",
      "evalLoss": "",
      "evaluationMetrics": {
        "arimaForecastingMetrics": {
          "arimaFittingMetrics": [
            {
              "aic": "",
              "logLikelihood": "",
              "variance": ""
            }
          ],
          "arimaSingleModelForecastingMetrics": [
            {
              "arimaFittingMetrics": {},
              "hasDrift": false,
              "hasHolidayEffect": false,
              "hasSpikesAndDips": false,
              "hasStepChanges": false,
              "nonSeasonalOrder": {
                "d": "",
                "p": "",
                "q": ""
              },
              "seasonalPeriods": [],
              "timeSeriesId": "",
              "timeSeriesIds": []
            }
          ],
          "hasDrift": [],
          "nonSeasonalOrder": [
            {}
          ],
          "seasonalPeriods": [],
          "timeSeriesId": []
        },
        "binaryClassificationMetrics": {
          "aggregateClassificationMetrics": {
            "accuracy": "",
            "f1Score": "",
            "logLoss": "",
            "precision": "",
            "recall": "",
            "rocAuc": "",
            "threshold": ""
          },
          "binaryConfusionMatrixList": [
            {
              "accuracy": "",
              "f1Score": "",
              "falseNegatives": "",
              "falsePositives": "",
              "positiveClassThreshold": "",
              "precision": "",
              "recall": "",
              "trueNegatives": "",
              "truePositives": ""
            }
          ],
          "negativeLabel": "",
          "positiveLabel": ""
        },
        "clusteringMetrics": {
          "clusters": [
            {
              "centroidId": "",
              "count": "",
              "featureValues": [
                {
                  "categoricalValue": {
                    "categoryCounts": [
                      {
                        "category": "",
                        "count": ""
                      }
                    ]
                  },
                  "featureColumn": "",
                  "numericalValue": ""
                }
              ]
            }
          ],
          "daviesBouldinIndex": "",
          "meanSquaredDistance": ""
        },
        "dimensionalityReductionMetrics": {
          "totalExplainedVarianceRatio": ""
        },
        "multiClassClassificationMetrics": {
          "aggregateClassificationMetrics": {},
          "confusionMatrixList": [
            {
              "confidenceThreshold": "",
              "rows": [
                {
                  "actualLabel": "",
                  "entries": [
                    {
                      "itemCount": "",
                      "predictedLabel": ""
                    }
                  ]
                }
              ]
            }
          ]
        },
        "rankingMetrics": {
          "averageRank": "",
          "meanAveragePrecision": "",
          "meanSquaredError": "",
          "normalizedDiscountedCumulativeGain": ""
        },
        "regressionMetrics": {
          "meanAbsoluteError": "",
          "meanSquaredError": "",
          "meanSquaredLogError": "",
          "medianAbsoluteError": "",
          "rSquared": ""
        }
      },
      "hparamTuningEvaluationMetrics": {},
      "hparams": {
        "adjustStepChanges": false,
        "autoArima": false,
        "autoArimaMaxOrder": "",
        "autoArimaMinOrder": "",
        "batchSize": "",
        "boosterType": "",
        "calculatePValues": false,
        "cleanSpikesAndDips": false,
        "colorSpace": "",
        "colsampleBylevel": "",
        "colsampleBynode": "",
        "colsampleBytree": "",
        "dartNormalizeType": "",
        "dataFrequency": "",
        "dataSplitColumn": "",
        "dataSplitEvalFraction": "",
        "dataSplitMethod": "",
        "decomposeTimeSeries": false,
        "distanceType": "",
        "dropout": "",
        "earlyStop": false,
        "enableGlobalExplain": false,
        "feedbackType": "",
        "hiddenUnits": [],
        "holidayRegion": "",
        "horizon": "",
        "hparamTuningObjectives": [],
        "includeDrift": false,
        "initialLearnRate": "",
        "inputLabelColumns": [],
        "integratedGradientsNumSteps": "",
        "itemColumn": "",
        "kmeansInitializationColumn": "",
        "kmeansInitializationMethod": "",
        "l1Regularization": "",
        "l2Regularization": "",
        "labelClassWeights": {},
        "learnRate": "",
        "learnRateStrategy": "",
        "lossType": "",
        "maxIterations": "",
        "maxParallelTrials": "",
        "maxTimeSeriesLength": "",
        "maxTreeDepth": "",
        "minRelativeProgress": "",
        "minSplitLoss": "",
        "minTimeSeriesLength": "",
        "minTreeChildWeight": "",
        "modelUri": "",
        "nonSeasonalOrder": {},
        "numClusters": "",
        "numFactors": "",
        "numParallelTree": "",
        "numTrials": "",
        "optimizationStrategy": "",
        "preserveInputStructs": false,
        "sampledShapleyNumPaths": "",
        "subsample": "",
        "timeSeriesDataColumn": "",
        "timeSeriesIdColumn": "",
        "timeSeriesIdColumns": [],
        "timeSeriesLengthFraction": "",
        "timeSeriesTimestampColumn": "",
        "treeMethod": "",
        "trendSmoothingWindowSize": "",
        "userColumn": "",
        "walsAlpha": "",
        "warmStart": false
      },
      "startTimeMs": "",
      "status": "",
      "trainingLoss": "",
      "trialId": ""
    }
  ],
  "labelColumns": [
    {}
  ],
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "modelReference": {
    "datasetId": "",
    "modelId": "",
    "projectId": ""
  },
  "modelType": "",
  "optimalTrialIds": [],
  "trainingRuns": [
    {
      "classLevelGlobalExplanations": [
        {
          "classLabel": "",
          "explanations": [
            {
              "attribution": "",
              "featureName": ""
            }
          ]
        }
      ],
      "dataSplitResult": {
        "evaluationTable": {
          "datasetId": "",
          "projectId": "",
          "tableId": ""
        },
        "testTable": {},
        "trainingTable": {}
      },
      "evaluationMetrics": {},
      "modelLevelGlobalExplanation": {},
      "results": [
        {
          "durationMs": "",
          "evalLoss": "",
          "index": 0,
          "learnRate": "",
          "trainingLoss": ""
        }
      ],
      "startTime": "",
      "trainingOptions": {},
      "trainingStartTime": "",
      "vertexAiModelId": "",
      "vertexAiModelVersion": ""
    }
  ]
}' |  \
  http PATCH {{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'content-type: application/json' \
  --body-data '{\n  "bestTrialId": "",\n  "creationTime": "",\n  "defaultTrialId": "",\n  "description": "",\n  "encryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "etag": "",\n  "expirationTime": "",\n  "featureColumns": [\n    {\n      "name": "",\n      "type": {\n        "arrayElementType": "",\n        "structType": {\n          "fields": []\n        },\n        "typeKind": ""\n      }\n    }\n  ],\n  "friendlyName": "",\n  "hparamSearchSpaces": {\n    "activationFn": {\n      "candidates": []\n    },\n    "batchSize": {\n      "candidates": {\n        "candidates": []\n      },\n      "range": {\n        "max": "",\n        "min": ""\n      }\n    },\n    "boosterType": {},\n    "colsampleBylevel": {\n      "candidates": {\n        "candidates": []\n      },\n      "range": {\n        "max": "",\n        "min": ""\n      }\n    },\n    "colsampleBynode": {},\n    "colsampleBytree": {},\n    "dartNormalizeType": {},\n    "dropout": {},\n    "hiddenUnits": {\n      "candidates": [\n        {\n          "elements": []\n        }\n      ]\n    },\n    "l1Reg": {},\n    "l2Reg": {},\n    "learnRate": {},\n    "maxTreeDepth": {},\n    "minSplitLoss": {},\n    "minTreeChildWeight": {},\n    "numClusters": {},\n    "numFactors": {},\n    "numParallelTree": {},\n    "optimizer": {},\n    "subsample": {},\n    "treeMethod": {},\n    "walsAlpha": {}\n  },\n  "hparamTrials": [\n    {\n      "endTimeMs": "",\n      "errorMessage": "",\n      "evalLoss": "",\n      "evaluationMetrics": {\n        "arimaForecastingMetrics": {\n          "arimaFittingMetrics": [\n            {\n              "aic": "",\n              "logLikelihood": "",\n              "variance": ""\n            }\n          ],\n          "arimaSingleModelForecastingMetrics": [\n            {\n              "arimaFittingMetrics": {},\n              "hasDrift": false,\n              "hasHolidayEffect": false,\n              "hasSpikesAndDips": false,\n              "hasStepChanges": false,\n              "nonSeasonalOrder": {\n                "d": "",\n                "p": "",\n                "q": ""\n              },\n              "seasonalPeriods": [],\n              "timeSeriesId": "",\n              "timeSeriesIds": []\n            }\n          ],\n          "hasDrift": [],\n          "nonSeasonalOrder": [\n            {}\n          ],\n          "seasonalPeriods": [],\n          "timeSeriesId": []\n        },\n        "binaryClassificationMetrics": {\n          "aggregateClassificationMetrics": {\n            "accuracy": "",\n            "f1Score": "",\n            "logLoss": "",\n            "precision": "",\n            "recall": "",\n            "rocAuc": "",\n            "threshold": ""\n          },\n          "binaryConfusionMatrixList": [\n            {\n              "accuracy": "",\n              "f1Score": "",\n              "falseNegatives": "",\n              "falsePositives": "",\n              "positiveClassThreshold": "",\n              "precision": "",\n              "recall": "",\n              "trueNegatives": "",\n              "truePositives": ""\n            }\n          ],\n          "negativeLabel": "",\n          "positiveLabel": ""\n        },\n        "clusteringMetrics": {\n          "clusters": [\n            {\n              "centroidId": "",\n              "count": "",\n              "featureValues": [\n                {\n                  "categoricalValue": {\n                    "categoryCounts": [\n                      {\n                        "category": "",\n                        "count": ""\n                      }\n                    ]\n                  },\n                  "featureColumn": "",\n                  "numericalValue": ""\n                }\n              ]\n            }\n          ],\n          "daviesBouldinIndex": "",\n          "meanSquaredDistance": ""\n        },\n        "dimensionalityReductionMetrics": {\n          "totalExplainedVarianceRatio": ""\n        },\n        "multiClassClassificationMetrics": {\n          "aggregateClassificationMetrics": {},\n          "confusionMatrixList": [\n            {\n              "confidenceThreshold": "",\n              "rows": [\n                {\n                  "actualLabel": "",\n                  "entries": [\n                    {\n                      "itemCount": "",\n                      "predictedLabel": ""\n                    }\n                  ]\n                }\n              ]\n            }\n          ]\n        },\n        "rankingMetrics": {\n          "averageRank": "",\n          "meanAveragePrecision": "",\n          "meanSquaredError": "",\n          "normalizedDiscountedCumulativeGain": ""\n        },\n        "regressionMetrics": {\n          "meanAbsoluteError": "",\n          "meanSquaredError": "",\n          "meanSquaredLogError": "",\n          "medianAbsoluteError": "",\n          "rSquared": ""\n        }\n      },\n      "hparamTuningEvaluationMetrics": {},\n      "hparams": {\n        "adjustStepChanges": false,\n        "autoArima": false,\n        "autoArimaMaxOrder": "",\n        "autoArimaMinOrder": "",\n        "batchSize": "",\n        "boosterType": "",\n        "calculatePValues": false,\n        "cleanSpikesAndDips": false,\n        "colorSpace": "",\n        "colsampleBylevel": "",\n        "colsampleBynode": "",\n        "colsampleBytree": "",\n        "dartNormalizeType": "",\n        "dataFrequency": "",\n        "dataSplitColumn": "",\n        "dataSplitEvalFraction": "",\n        "dataSplitMethod": "",\n        "decomposeTimeSeries": false,\n        "distanceType": "",\n        "dropout": "",\n        "earlyStop": false,\n        "enableGlobalExplain": false,\n        "feedbackType": "",\n        "hiddenUnits": [],\n        "holidayRegion": "",\n        "horizon": "",\n        "hparamTuningObjectives": [],\n        "includeDrift": false,\n        "initialLearnRate": "",\n        "inputLabelColumns": [],\n        "integratedGradientsNumSteps": "",\n        "itemColumn": "",\n        "kmeansInitializationColumn": "",\n        "kmeansInitializationMethod": "",\n        "l1Regularization": "",\n        "l2Regularization": "",\n        "labelClassWeights": {},\n        "learnRate": "",\n        "learnRateStrategy": "",\n        "lossType": "",\n        "maxIterations": "",\n        "maxParallelTrials": "",\n        "maxTimeSeriesLength": "",\n        "maxTreeDepth": "",\n        "minRelativeProgress": "",\n        "minSplitLoss": "",\n        "minTimeSeriesLength": "",\n        "minTreeChildWeight": "",\n        "modelUri": "",\n        "nonSeasonalOrder": {},\n        "numClusters": "",\n        "numFactors": "",\n        "numParallelTree": "",\n        "numTrials": "",\n        "optimizationStrategy": "",\n        "preserveInputStructs": false,\n        "sampledShapleyNumPaths": "",\n        "subsample": "",\n        "timeSeriesDataColumn": "",\n        "timeSeriesIdColumn": "",\n        "timeSeriesIdColumns": [],\n        "timeSeriesLengthFraction": "",\n        "timeSeriesTimestampColumn": "",\n        "treeMethod": "",\n        "trendSmoothingWindowSize": "",\n        "userColumn": "",\n        "walsAlpha": "",\n        "warmStart": false\n      },\n      "startTimeMs": "",\n      "status": "",\n      "trainingLoss": "",\n      "trialId": ""\n    }\n  ],\n  "labelColumns": [\n    {}\n  ],\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "modelReference": {\n    "datasetId": "",\n    "modelId": "",\n    "projectId": ""\n  },\n  "modelType": "",\n  "optimalTrialIds": [],\n  "trainingRuns": [\n    {\n      "classLevelGlobalExplanations": [\n        {\n          "classLabel": "",\n          "explanations": [\n            {\n              "attribution": "",\n              "featureName": ""\n            }\n          ]\n        }\n      ],\n      "dataSplitResult": {\n        "evaluationTable": {\n          "datasetId": "",\n          "projectId": "",\n          "tableId": ""\n        },\n        "testTable": {},\n        "trainingTable": {}\n      },\n      "evaluationMetrics": {},\n      "modelLevelGlobalExplanation": {},\n      "results": [\n        {\n          "durationMs": "",\n          "evalLoss": "",\n          "index": 0,\n          "learnRate": "",\n          "trainingLoss": ""\n        }\n      ],\n      "startTime": "",\n      "trainingOptions": {},\n      "trainingStartTime": "",\n      "vertexAiModelId": "",\n      "vertexAiModelVersion": ""\n    }\n  ]\n}' \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "bestTrialId": "",
  "creationTime": "",
  "defaultTrialId": "",
  "description": "",
  "encryptionConfiguration": ["kmsKeyName": ""],
  "etag": "",
  "expirationTime": "",
  "featureColumns": [
    [
      "name": "",
      "type": [
        "arrayElementType": "",
        "structType": ["fields": []],
        "typeKind": ""
      ]
    ]
  ],
  "friendlyName": "",
  "hparamSearchSpaces": [
    "activationFn": ["candidates": []],
    "batchSize": [
      "candidates": ["candidates": []],
      "range": [
        "max": "",
        "min": ""
      ]
    ],
    "boosterType": [],
    "colsampleBylevel": [
      "candidates": ["candidates": []],
      "range": [
        "max": "",
        "min": ""
      ]
    ],
    "colsampleBynode": [],
    "colsampleBytree": [],
    "dartNormalizeType": [],
    "dropout": [],
    "hiddenUnits": ["candidates": [["elements": []]]],
    "l1Reg": [],
    "l2Reg": [],
    "learnRate": [],
    "maxTreeDepth": [],
    "minSplitLoss": [],
    "minTreeChildWeight": [],
    "numClusters": [],
    "numFactors": [],
    "numParallelTree": [],
    "optimizer": [],
    "subsample": [],
    "treeMethod": [],
    "walsAlpha": []
  ],
  "hparamTrials": [
    [
      "endTimeMs": "",
      "errorMessage": "",
      "evalLoss": "",
      "evaluationMetrics": [
        "arimaForecastingMetrics": [
          "arimaFittingMetrics": [
            [
              "aic": "",
              "logLikelihood": "",
              "variance": ""
            ]
          ],
          "arimaSingleModelForecastingMetrics": [
            [
              "arimaFittingMetrics": [],
              "hasDrift": false,
              "hasHolidayEffect": false,
              "hasSpikesAndDips": false,
              "hasStepChanges": false,
              "nonSeasonalOrder": [
                "d": "",
                "p": "",
                "q": ""
              ],
              "seasonalPeriods": [],
              "timeSeriesId": "",
              "timeSeriesIds": []
            ]
          ],
          "hasDrift": [],
          "nonSeasonalOrder": [[]],
          "seasonalPeriods": [],
          "timeSeriesId": []
        ],
        "binaryClassificationMetrics": [
          "aggregateClassificationMetrics": [
            "accuracy": "",
            "f1Score": "",
            "logLoss": "",
            "precision": "",
            "recall": "",
            "rocAuc": "",
            "threshold": ""
          ],
          "binaryConfusionMatrixList": [
            [
              "accuracy": "",
              "f1Score": "",
              "falseNegatives": "",
              "falsePositives": "",
              "positiveClassThreshold": "",
              "precision": "",
              "recall": "",
              "trueNegatives": "",
              "truePositives": ""
            ]
          ],
          "negativeLabel": "",
          "positiveLabel": ""
        ],
        "clusteringMetrics": [
          "clusters": [
            [
              "centroidId": "",
              "count": "",
              "featureValues": [
                [
                  "categoricalValue": ["categoryCounts": [
                      [
                        "category": "",
                        "count": ""
                      ]
                    ]],
                  "featureColumn": "",
                  "numericalValue": ""
                ]
              ]
            ]
          ],
          "daviesBouldinIndex": "",
          "meanSquaredDistance": ""
        ],
        "dimensionalityReductionMetrics": ["totalExplainedVarianceRatio": ""],
        "multiClassClassificationMetrics": [
          "aggregateClassificationMetrics": [],
          "confusionMatrixList": [
            [
              "confidenceThreshold": "",
              "rows": [
                [
                  "actualLabel": "",
                  "entries": [
                    [
                      "itemCount": "",
                      "predictedLabel": ""
                    ]
                  ]
                ]
              ]
            ]
          ]
        ],
        "rankingMetrics": [
          "averageRank": "",
          "meanAveragePrecision": "",
          "meanSquaredError": "",
          "normalizedDiscountedCumulativeGain": ""
        ],
        "regressionMetrics": [
          "meanAbsoluteError": "",
          "meanSquaredError": "",
          "meanSquaredLogError": "",
          "medianAbsoluteError": "",
          "rSquared": ""
        ]
      ],
      "hparamTuningEvaluationMetrics": [],
      "hparams": [
        "adjustStepChanges": false,
        "autoArima": false,
        "autoArimaMaxOrder": "",
        "autoArimaMinOrder": "",
        "batchSize": "",
        "boosterType": "",
        "calculatePValues": false,
        "cleanSpikesAndDips": false,
        "colorSpace": "",
        "colsampleBylevel": "",
        "colsampleBynode": "",
        "colsampleBytree": "",
        "dartNormalizeType": "",
        "dataFrequency": "",
        "dataSplitColumn": "",
        "dataSplitEvalFraction": "",
        "dataSplitMethod": "",
        "decomposeTimeSeries": false,
        "distanceType": "",
        "dropout": "",
        "earlyStop": false,
        "enableGlobalExplain": false,
        "feedbackType": "",
        "hiddenUnits": [],
        "holidayRegion": "",
        "horizon": "",
        "hparamTuningObjectives": [],
        "includeDrift": false,
        "initialLearnRate": "",
        "inputLabelColumns": [],
        "integratedGradientsNumSteps": "",
        "itemColumn": "",
        "kmeansInitializationColumn": "",
        "kmeansInitializationMethod": "",
        "l1Regularization": "",
        "l2Regularization": "",
        "labelClassWeights": [],
        "learnRate": "",
        "learnRateStrategy": "",
        "lossType": "",
        "maxIterations": "",
        "maxParallelTrials": "",
        "maxTimeSeriesLength": "",
        "maxTreeDepth": "",
        "minRelativeProgress": "",
        "minSplitLoss": "",
        "minTimeSeriesLength": "",
        "minTreeChildWeight": "",
        "modelUri": "",
        "nonSeasonalOrder": [],
        "numClusters": "",
        "numFactors": "",
        "numParallelTree": "",
        "numTrials": "",
        "optimizationStrategy": "",
        "preserveInputStructs": false,
        "sampledShapleyNumPaths": "",
        "subsample": "",
        "timeSeriesDataColumn": "",
        "timeSeriesIdColumn": "",
        "timeSeriesIdColumns": [],
        "timeSeriesLengthFraction": "",
        "timeSeriesTimestampColumn": "",
        "treeMethod": "",
        "trendSmoothingWindowSize": "",
        "userColumn": "",
        "walsAlpha": "",
        "warmStart": false
      ],
      "startTimeMs": "",
      "status": "",
      "trainingLoss": "",
      "trialId": ""
    ]
  ],
  "labelColumns": [[]],
  "labels": [],
  "lastModifiedTime": "",
  "location": "",
  "modelReference": [
    "datasetId": "",
    "modelId": "",
    "projectId": ""
  ],
  "modelType": "",
  "optimalTrialIds": [],
  "trainingRuns": [
    [
      "classLevelGlobalExplanations": [
        [
          "classLabel": "",
          "explanations": [
            [
              "attribution": "",
              "featureName": ""
            ]
          ]
        ]
      ],
      "dataSplitResult": [
        "evaluationTable": [
          "datasetId": "",
          "projectId": "",
          "tableId": ""
        ],
        "testTable": [],
        "trainingTable": []
      ],
      "evaluationMetrics": [],
      "modelLevelGlobalExplanation": [],
      "results": [
        [
          "durationMs": "",
          "evalLoss": "",
          "index": 0,
          "learnRate": "",
          "trainingLoss": ""
        ]
      ],
      "startTime": "",
      "trainingOptions": [],
      "trainingStartTime": "",
      "vertexAiModelId": "",
      "vertexAiModelVersion": ""
    ]
  ]
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/models/:modelId")! 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()
GET bigquery.projects.getServiceAccount
{{baseUrl}}/projects/:projectId/serviceAccount
QUERY PARAMS

projectId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/serviceAccount");

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

(client/get "{{baseUrl}}/projects/:projectId/serviceAccount")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/serviceAccount"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/serviceAccount"

	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/projects/:projectId/serviceAccount HTTP/1.1
Host: example.com

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/serviceAccount'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/serviceAccount")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/serviceAccount',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/serviceAccount'
};

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

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

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/serviceAccount');

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}}/projects/:projectId/serviceAccount'
};

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

const url = '{{baseUrl}}/projects/:projectId/serviceAccount';
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}}/projects/:projectId/serviceAccount"]
                                                       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}}/projects/:projectId/serviceAccount" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/serviceAccount');
$request->setMethod(HTTP_METH_GET);

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

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

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

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

conn.request("GET", "/baseUrl/projects/:projectId/serviceAccount")

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

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

url = "{{baseUrl}}/projects/:projectId/serviceAccount"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/serviceAccount"

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

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

url = URI("{{baseUrl}}/projects/:projectId/serviceAccount")

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/projects/:projectId/serviceAccount') do |req|
end

puts response.status
puts response.body
use reqwest;

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

    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}}/projects/:projectId/serviceAccount
http GET {{baseUrl}}/projects/:projectId/serviceAccount
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/projects/:projectId/serviceAccount
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/serviceAccount")! 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 bigquery.projects.list
{{baseUrl}}/projects
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects");

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

(client/get "{{baseUrl}}/projects")
require "http/client"

url = "{{baseUrl}}/projects"

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

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

func main() {

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

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

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

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

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

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

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

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

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

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

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

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

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

  res.on('data', function (chunk) {
    chunks.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}}/projects'};

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

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

const req = unirest('GET', '{{baseUrl}}/projects');

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}}/projects'};

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/projects")

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

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

url = "{{baseUrl}}/projects"

response = requests.get(url)

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

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

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

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

url = URI("{{baseUrl}}/projects")

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/projects') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

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

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

dataTask.resume()
DELETE bigquery.routines.delete
{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId
QUERY PARAMS

projectId
datasetId
routineId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId");

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

(client/delete "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"

	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/projects/:projectId/datasets/:datasetId/routines/:routineId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"))
    .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}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .asString();
const 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}}/projects/:projectId/datasets/:datasetId/routines/:routineId');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .delete(null)
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/routines/:routineId',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId/routines/:routineId'
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId');

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}}/projects/:projectId/datasets/:datasetId/routines/:routineId'
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId';
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}}/projects/:projectId/datasets/:datasetId/routines/:routineId"]
                                                       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}}/projects/:projectId/datasets/:datasetId/routines/:routineId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId');
$request->setMethod(HTTP_METH_DELETE);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/projects/:projectId/datasets/:datasetId/routines/:routineId")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"

response = requests.delete(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")

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/projects/:projectId/datasets/:datasetId/routines/:routineId') do |req|
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId";

    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}}/projects/:projectId/datasets/:datasetId/routines/:routineId
http DELETE {{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")! 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 bigquery.routines.get
{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId
QUERY PARAMS

projectId
datasetId
routineId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId");

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

(client/get "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"

	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/projects/:projectId/datasets/:datasetId/routines/:routineId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"))
    .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}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .asString();
const 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}}/projects/:projectId/datasets/:datasetId/routines/:routineId');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/routines/:routineId',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId/routines/:routineId'
};

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

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

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId');

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}}/projects/:projectId/datasets/:datasetId/routines/:routineId'
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId';
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}}/projects/:projectId/datasets/:datasetId/routines/:routineId"]
                                                       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}}/projects/:projectId/datasets/:datasetId/routines/:routineId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/projects/:projectId/datasets/:datasetId/routines/:routineId")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")

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/projects/:projectId/datasets/:datasetId/routines/:routineId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId";

    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}}/projects/:projectId/datasets/:datasetId/routines/:routineId
http GET {{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")! 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 bigquery.routines.insert
{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines
QUERY PARAMS

projectId
datasetId
BODY json

{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}");

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

(client/post "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines" {:content-type :json
                                                                                             :form-params {:arguments [{:argumentKind ""
                                                                                                                        :dataType {:arrayElementType ""
                                                                                                                                   :structType {:fields []}
                                                                                                                                   :typeKind ""}
                                                                                                                        :mode ""
                                                                                                                        :name ""}]
                                                                                                           :creationTime ""
                                                                                                           :definitionBody ""
                                                                                                           :description ""
                                                                                                           :determinismLevel ""
                                                                                                           :etag ""
                                                                                                           :importedLibraries []
                                                                                                           :language ""
                                                                                                           :lastModifiedTime ""
                                                                                                           :remoteFunctionOptions {:connection ""
                                                                                                                                   :endpoint ""
                                                                                                                                   :maxBatchingRows ""
                                                                                                                                   :userDefinedContext {}}
                                                                                                           :returnTableType {:columns [{:name ""
                                                                                                                                        :type {}}]}
                                                                                                           :returnType {}
                                                                                                           :routineReference {:datasetId ""
                                                                                                                              :projectId ""
                                                                                                                              :routineId ""}
                                                                                                           :routineType ""
                                                                                                           :sparkOptions {:archiveUris []
                                                                                                                          :connection ""
                                                                                                                          :containerImage ""
                                                                                                                          :fileUris []
                                                                                                                          :jarUris []
                                                                                                                          :mainClass ""
                                                                                                                          :mainFileUri ""
                                                                                                                          :properties {}
                                                                                                                          :pyFileUris []
                                                                                                                          :runtimeVersion ""}
                                                                                                           :strictMode false}})
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": 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}}/projects/:projectId/datasets/:datasetId/routines"),
    Content = new StringContent("{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": 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}}/projects/:projectId/datasets/:datasetId/routines");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines"

	payload := strings.NewReader("{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": 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/projects/:projectId/datasets/:datasetId/routines HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1058

{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": 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  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines")
  .header("content-type", "application/json")
  .body("{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}")
  .asString();
const data = JSON.stringify({
  arguments: [
    {
      argumentKind: '',
      dataType: {
        arrayElementType: '',
        structType: {
          fields: []
        },
        typeKind: ''
      },
      mode: '',
      name: ''
    }
  ],
  creationTime: '',
  definitionBody: '',
  description: '',
  determinismLevel: '',
  etag: '',
  importedLibraries: [],
  language: '',
  lastModifiedTime: '',
  remoteFunctionOptions: {
    connection: '',
    endpoint: '',
    maxBatchingRows: '',
    userDefinedContext: {}
  },
  returnTableType: {
    columns: [
      {
        name: '',
        type: {}
      }
    ]
  },
  returnType: {},
  routineReference: {
    datasetId: '',
    projectId: '',
    routineId: ''
  },
  routineType: '',
  sparkOptions: {
    archiveUris: [],
    connection: '',
    containerImage: '',
    fileUris: [],
    jarUris: [],
    mainClass: '',
    mainFileUri: '',
    properties: {},
    pyFileUris: [],
    runtimeVersion: ''
  },
  strictMode: 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}}/projects/:projectId/datasets/:datasetId/routines');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines',
  headers: {'content-type': 'application/json'},
  data: {
    arguments: [
      {
        argumentKind: '',
        dataType: {arrayElementType: '', structType: {fields: []}, typeKind: ''},
        mode: '',
        name: ''
      }
    ],
    creationTime: '',
    definitionBody: '',
    description: '',
    determinismLevel: '',
    etag: '',
    importedLibraries: [],
    language: '',
    lastModifiedTime: '',
    remoteFunctionOptions: {connection: '', endpoint: '', maxBatchingRows: '', userDefinedContext: {}},
    returnTableType: {columns: [{name: '', type: {}}]},
    returnType: {},
    routineReference: {datasetId: '', projectId: '', routineId: ''},
    routineType: '',
    sparkOptions: {
      archiveUris: [],
      connection: '',
      containerImage: '',
      fileUris: [],
      jarUris: [],
      mainClass: '',
      mainFileUri: '',
      properties: {},
      pyFileUris: [],
      runtimeVersion: ''
    },
    strictMode: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"arguments":[{"argumentKind":"","dataType":{"arrayElementType":"","structType":{"fields":[]},"typeKind":""},"mode":"","name":""}],"creationTime":"","definitionBody":"","description":"","determinismLevel":"","etag":"","importedLibraries":[],"language":"","lastModifiedTime":"","remoteFunctionOptions":{"connection":"","endpoint":"","maxBatchingRows":"","userDefinedContext":{}},"returnTableType":{"columns":[{"name":"","type":{}}]},"returnType":{},"routineReference":{"datasetId":"","projectId":"","routineId":""},"routineType":"","sparkOptions":{"archiveUris":[],"connection":"","containerImage":"","fileUris":[],"jarUris":[],"mainClass":"","mainFileUri":"","properties":{},"pyFileUris":[],"runtimeVersion":""},"strictMode":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}}/projects/:projectId/datasets/:datasetId/routines',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "arguments": [\n    {\n      "argumentKind": "",\n      "dataType": {\n        "arrayElementType": "",\n        "structType": {\n          "fields": []\n        },\n        "typeKind": ""\n      },\n      "mode": "",\n      "name": ""\n    }\n  ],\n  "creationTime": "",\n  "definitionBody": "",\n  "description": "",\n  "determinismLevel": "",\n  "etag": "",\n  "importedLibraries": [],\n  "language": "",\n  "lastModifiedTime": "",\n  "remoteFunctionOptions": {\n    "connection": "",\n    "endpoint": "",\n    "maxBatchingRows": "",\n    "userDefinedContext": {}\n  },\n  "returnTableType": {\n    "columns": [\n      {\n        "name": "",\n        "type": {}\n      }\n    ]\n  },\n  "returnType": {},\n  "routineReference": {\n    "datasetId": "",\n    "projectId": "",\n    "routineId": ""\n  },\n  "routineType": "",\n  "sparkOptions": {\n    "archiveUris": [],\n    "connection": "",\n    "containerImage": "",\n    "fileUris": [],\n    "jarUris": [],\n    "mainClass": "",\n    "mainFileUri": "",\n    "properties": {},\n    "pyFileUris": [],\n    "runtimeVersion": ""\n  },\n  "strictMode": 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  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines")
  .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/projects/:projectId/datasets/:datasetId/routines',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  arguments: [
    {
      argumentKind: '',
      dataType: {arrayElementType: '', structType: {fields: []}, typeKind: ''},
      mode: '',
      name: ''
    }
  ],
  creationTime: '',
  definitionBody: '',
  description: '',
  determinismLevel: '',
  etag: '',
  importedLibraries: [],
  language: '',
  lastModifiedTime: '',
  remoteFunctionOptions: {connection: '', endpoint: '', maxBatchingRows: '', userDefinedContext: {}},
  returnTableType: {columns: [{name: '', type: {}}]},
  returnType: {},
  routineReference: {datasetId: '', projectId: '', routineId: ''},
  routineType: '',
  sparkOptions: {
    archiveUris: [],
    connection: '',
    containerImage: '',
    fileUris: [],
    jarUris: [],
    mainClass: '',
    mainFileUri: '',
    properties: {},
    pyFileUris: [],
    runtimeVersion: ''
  },
  strictMode: false
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines',
  headers: {'content-type': 'application/json'},
  body: {
    arguments: [
      {
        argumentKind: '',
        dataType: {arrayElementType: '', structType: {fields: []}, typeKind: ''},
        mode: '',
        name: ''
      }
    ],
    creationTime: '',
    definitionBody: '',
    description: '',
    determinismLevel: '',
    etag: '',
    importedLibraries: [],
    language: '',
    lastModifiedTime: '',
    remoteFunctionOptions: {connection: '', endpoint: '', maxBatchingRows: '', userDefinedContext: {}},
    returnTableType: {columns: [{name: '', type: {}}]},
    returnType: {},
    routineReference: {datasetId: '', projectId: '', routineId: ''},
    routineType: '',
    sparkOptions: {
      archiveUris: [],
      connection: '',
      containerImage: '',
      fileUris: [],
      jarUris: [],
      mainClass: '',
      mainFileUri: '',
      properties: {},
      pyFileUris: [],
      runtimeVersion: ''
    },
    strictMode: 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}}/projects/:projectId/datasets/:datasetId/routines');

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

req.type('json');
req.send({
  arguments: [
    {
      argumentKind: '',
      dataType: {
        arrayElementType: '',
        structType: {
          fields: []
        },
        typeKind: ''
      },
      mode: '',
      name: ''
    }
  ],
  creationTime: '',
  definitionBody: '',
  description: '',
  determinismLevel: '',
  etag: '',
  importedLibraries: [],
  language: '',
  lastModifiedTime: '',
  remoteFunctionOptions: {
    connection: '',
    endpoint: '',
    maxBatchingRows: '',
    userDefinedContext: {}
  },
  returnTableType: {
    columns: [
      {
        name: '',
        type: {}
      }
    ]
  },
  returnType: {},
  routineReference: {
    datasetId: '',
    projectId: '',
    routineId: ''
  },
  routineType: '',
  sparkOptions: {
    archiveUris: [],
    connection: '',
    containerImage: '',
    fileUris: [],
    jarUris: [],
    mainClass: '',
    mainFileUri: '',
    properties: {},
    pyFileUris: [],
    runtimeVersion: ''
  },
  strictMode: 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}}/projects/:projectId/datasets/:datasetId/routines',
  headers: {'content-type': 'application/json'},
  data: {
    arguments: [
      {
        argumentKind: '',
        dataType: {arrayElementType: '', structType: {fields: []}, typeKind: ''},
        mode: '',
        name: ''
      }
    ],
    creationTime: '',
    definitionBody: '',
    description: '',
    determinismLevel: '',
    etag: '',
    importedLibraries: [],
    language: '',
    lastModifiedTime: '',
    remoteFunctionOptions: {connection: '', endpoint: '', maxBatchingRows: '', userDefinedContext: {}},
    returnTableType: {columns: [{name: '', type: {}}]},
    returnType: {},
    routineReference: {datasetId: '', projectId: '', routineId: ''},
    routineType: '',
    sparkOptions: {
      archiveUris: [],
      connection: '',
      containerImage: '',
      fileUris: [],
      jarUris: [],
      mainClass: '',
      mainFileUri: '',
      properties: {},
      pyFileUris: [],
      runtimeVersion: ''
    },
    strictMode: false
  }
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"arguments":[{"argumentKind":"","dataType":{"arrayElementType":"","structType":{"fields":[]},"typeKind":""},"mode":"","name":""}],"creationTime":"","definitionBody":"","description":"","determinismLevel":"","etag":"","importedLibraries":[],"language":"","lastModifiedTime":"","remoteFunctionOptions":{"connection":"","endpoint":"","maxBatchingRows":"","userDefinedContext":{}},"returnTableType":{"columns":[{"name":"","type":{}}]},"returnType":{},"routineReference":{"datasetId":"","projectId":"","routineId":""},"routineType":"","sparkOptions":{"archiveUris":[],"connection":"","containerImage":"","fileUris":[],"jarUris":[],"mainClass":"","mainFileUri":"","properties":{},"pyFileUris":[],"runtimeVersion":""},"strictMode":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 = @{ @"arguments": @[ @{ @"argumentKind": @"", @"dataType": @{ @"arrayElementType": @"", @"structType": @{ @"fields": @[  ] }, @"typeKind": @"" }, @"mode": @"", @"name": @"" } ],
                              @"creationTime": @"",
                              @"definitionBody": @"",
                              @"description": @"",
                              @"determinismLevel": @"",
                              @"etag": @"",
                              @"importedLibraries": @[  ],
                              @"language": @"",
                              @"lastModifiedTime": @"",
                              @"remoteFunctionOptions": @{ @"connection": @"", @"endpoint": @"", @"maxBatchingRows": @"", @"userDefinedContext": @{  } },
                              @"returnTableType": @{ @"columns": @[ @{ @"name": @"", @"type": @{  } } ] },
                              @"returnType": @{  },
                              @"routineReference": @{ @"datasetId": @"", @"projectId": @"", @"routineId": @"" },
                              @"routineType": @"",
                              @"sparkOptions": @{ @"archiveUris": @[  ], @"connection": @"", @"containerImage": @"", @"fileUris": @[  ], @"jarUris": @[  ], @"mainClass": @"", @"mainFileUri": @"", @"properties": @{  }, @"pyFileUris": @[  ], @"runtimeVersion": @"" },
                              @"strictMode": @NO };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines"]
                                                       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}}/projects/:projectId/datasets/:datasetId/routines" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines",
  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([
    'arguments' => [
        [
                'argumentKind' => '',
                'dataType' => [
                                'arrayElementType' => '',
                                'structType' => [
                                                                'fields' => [
                                                                                                                                
                                                                ]
                                ],
                                'typeKind' => ''
                ],
                'mode' => '',
                'name' => ''
        ]
    ],
    'creationTime' => '',
    'definitionBody' => '',
    'description' => '',
    'determinismLevel' => '',
    'etag' => '',
    'importedLibraries' => [
        
    ],
    'language' => '',
    'lastModifiedTime' => '',
    'remoteFunctionOptions' => [
        'connection' => '',
        'endpoint' => '',
        'maxBatchingRows' => '',
        'userDefinedContext' => [
                
        ]
    ],
    'returnTableType' => [
        'columns' => [
                [
                                'name' => '',
                                'type' => [
                                                                
                                ]
                ]
        ]
    ],
    'returnType' => [
        
    ],
    'routineReference' => [
        'datasetId' => '',
        'projectId' => '',
        'routineId' => ''
    ],
    'routineType' => '',
    'sparkOptions' => [
        'archiveUris' => [
                
        ],
        'connection' => '',
        'containerImage' => '',
        'fileUris' => [
                
        ],
        'jarUris' => [
                
        ],
        'mainClass' => '',
        'mainFileUri' => '',
        'properties' => [
                
        ],
        'pyFileUris' => [
                
        ],
        'runtimeVersion' => ''
    ],
    'strictMode' => 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}}/projects/:projectId/datasets/:datasetId/routines', [
  'body' => '{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'arguments' => [
    [
        'argumentKind' => '',
        'dataType' => [
                'arrayElementType' => '',
                'structType' => [
                                'fields' => [
                                                                
                                ]
                ],
                'typeKind' => ''
        ],
        'mode' => '',
        'name' => ''
    ]
  ],
  'creationTime' => '',
  'definitionBody' => '',
  'description' => '',
  'determinismLevel' => '',
  'etag' => '',
  'importedLibraries' => [
    
  ],
  'language' => '',
  'lastModifiedTime' => '',
  'remoteFunctionOptions' => [
    'connection' => '',
    'endpoint' => '',
    'maxBatchingRows' => '',
    'userDefinedContext' => [
        
    ]
  ],
  'returnTableType' => [
    'columns' => [
        [
                'name' => '',
                'type' => [
                                
                ]
        ]
    ]
  ],
  'returnType' => [
    
  ],
  'routineReference' => [
    'datasetId' => '',
    'projectId' => '',
    'routineId' => ''
  ],
  'routineType' => '',
  'sparkOptions' => [
    'archiveUris' => [
        
    ],
    'connection' => '',
    'containerImage' => '',
    'fileUris' => [
        
    ],
    'jarUris' => [
        
    ],
    'mainClass' => '',
    'mainFileUri' => '',
    'properties' => [
        
    ],
    'pyFileUris' => [
        
    ],
    'runtimeVersion' => ''
  ],
  'strictMode' => null
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'arguments' => [
    [
        'argumentKind' => '',
        'dataType' => [
                'arrayElementType' => '',
                'structType' => [
                                'fields' => [
                                                                
                                ]
                ],
                'typeKind' => ''
        ],
        'mode' => '',
        'name' => ''
    ]
  ],
  'creationTime' => '',
  'definitionBody' => '',
  'description' => '',
  'determinismLevel' => '',
  'etag' => '',
  'importedLibraries' => [
    
  ],
  'language' => '',
  'lastModifiedTime' => '',
  'remoteFunctionOptions' => [
    'connection' => '',
    'endpoint' => '',
    'maxBatchingRows' => '',
    'userDefinedContext' => [
        
    ]
  ],
  'returnTableType' => [
    'columns' => [
        [
                'name' => '',
                'type' => [
                                
                ]
        ]
    ]
  ],
  'returnType' => [
    
  ],
  'routineReference' => [
    'datasetId' => '',
    'projectId' => '',
    'routineId' => ''
  ],
  'routineType' => '',
  'sparkOptions' => [
    'archiveUris' => [
        
    ],
    'connection' => '',
    'containerImage' => '',
    'fileUris' => [
        
    ],
    'jarUris' => [
        
    ],
    'mainClass' => '',
    'mainFileUri' => '',
    'properties' => [
        
    ],
    'pyFileUris' => [
        
    ],
    'runtimeVersion' => ''
  ],
  'strictMode' => null
]));
$request->setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines');
$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}}/projects/:projectId/datasets/:datasetId/routines' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}'
import http.client

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

payload = "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}"

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

conn.request("POST", "/baseUrl/projects/:projectId/datasets/:datasetId/routines", payload, headers)

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines"

payload = {
    "arguments": [
        {
            "argumentKind": "",
            "dataType": {
                "arrayElementType": "",
                "structType": { "fields": [] },
                "typeKind": ""
            },
            "mode": "",
            "name": ""
        }
    ],
    "creationTime": "",
    "definitionBody": "",
    "description": "",
    "determinismLevel": "",
    "etag": "",
    "importedLibraries": [],
    "language": "",
    "lastModifiedTime": "",
    "remoteFunctionOptions": {
        "connection": "",
        "endpoint": "",
        "maxBatchingRows": "",
        "userDefinedContext": {}
    },
    "returnTableType": { "columns": [
            {
                "name": "",
                "type": {}
            }
        ] },
    "returnType": {},
    "routineReference": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
    },
    "routineType": "",
    "sparkOptions": {
        "archiveUris": [],
        "connection": "",
        "containerImage": "",
        "fileUris": [],
        "jarUris": [],
        "mainClass": "",
        "mainFileUri": "",
        "properties": {},
        "pyFileUris": [],
        "runtimeVersion": ""
    },
    "strictMode": False
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines"

payload <- "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": 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}}/projects/:projectId/datasets/:datasetId/routines")

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  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": 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/projects/:projectId/datasets/:datasetId/routines') do |req|
  req.body = "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines";

    let payload = json!({
        "arguments": (
            json!({
                "argumentKind": "",
                "dataType": json!({
                    "arrayElementType": "",
                    "structType": json!({"fields": ()}),
                    "typeKind": ""
                }),
                "mode": "",
                "name": ""
            })
        ),
        "creationTime": "",
        "definitionBody": "",
        "description": "",
        "determinismLevel": "",
        "etag": "",
        "importedLibraries": (),
        "language": "",
        "lastModifiedTime": "",
        "remoteFunctionOptions": json!({
            "connection": "",
            "endpoint": "",
            "maxBatchingRows": "",
            "userDefinedContext": json!({})
        }),
        "returnTableType": json!({"columns": (
                json!({
                    "name": "",
                    "type": json!({})
                })
            )}),
        "returnType": json!({}),
        "routineReference": json!({
            "datasetId": "",
            "projectId": "",
            "routineId": ""
        }),
        "routineType": "",
        "sparkOptions": json!({
            "archiveUris": (),
            "connection": "",
            "containerImage": "",
            "fileUris": (),
            "jarUris": (),
            "mainClass": "",
            "mainFileUri": "",
            "properties": json!({}),
            "pyFileUris": (),
            "runtimeVersion": ""
        }),
        "strictMode": 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}}/projects/:projectId/datasets/:datasetId/routines \
  --header 'content-type: application/json' \
  --data '{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}'
echo '{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}' |  \
  http POST {{baseUrl}}/projects/:projectId/datasets/:datasetId/routines \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "arguments": [\n    {\n      "argumentKind": "",\n      "dataType": {\n        "arrayElementType": "",\n        "structType": {\n          "fields": []\n        },\n        "typeKind": ""\n      },\n      "mode": "",\n      "name": ""\n    }\n  ],\n  "creationTime": "",\n  "definitionBody": "",\n  "description": "",\n  "determinismLevel": "",\n  "etag": "",\n  "importedLibraries": [],\n  "language": "",\n  "lastModifiedTime": "",\n  "remoteFunctionOptions": {\n    "connection": "",\n    "endpoint": "",\n    "maxBatchingRows": "",\n    "userDefinedContext": {}\n  },\n  "returnTableType": {\n    "columns": [\n      {\n        "name": "",\n        "type": {}\n      }\n    ]\n  },\n  "returnType": {},\n  "routineReference": {\n    "datasetId": "",\n    "projectId": "",\n    "routineId": ""\n  },\n  "routineType": "",\n  "sparkOptions": {\n    "archiveUris": [],\n    "connection": "",\n    "containerImage": "",\n    "fileUris": [],\n    "jarUris": [],\n    "mainClass": "",\n    "mainFileUri": "",\n    "properties": {},\n    "pyFileUris": [],\n    "runtimeVersion": ""\n  },\n  "strictMode": false\n}' \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/routines
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "arguments": [
    [
      "argumentKind": "",
      "dataType": [
        "arrayElementType": "",
        "structType": ["fields": []],
        "typeKind": ""
      ],
      "mode": "",
      "name": ""
    ]
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": [
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": []
  ],
  "returnTableType": ["columns": [
      [
        "name": "",
        "type": []
      ]
    ]],
  "returnType": [],
  "routineReference": [
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  ],
  "routineType": "",
  "sparkOptions": [
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": [],
    "pyFileUris": [],
    "runtimeVersion": ""
  ],
  "strictMode": false
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines")! 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 bigquery.routines.list
{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines
QUERY PARAMS

projectId
datasetId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines");

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

(client/get "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines"

	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/projects/:projectId/datasets/:datasetId/routines HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines")
  .asString();
const 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}}/projects/:projectId/datasets/:datasetId/routines');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/routines',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId/routines'
};

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

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

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines');

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}}/projects/:projectId/datasets/:datasetId/routines'
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines';
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}}/projects/:projectId/datasets/:datasetId/routines"]
                                                       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}}/projects/:projectId/datasets/:datasetId/routines" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/projects/:projectId/datasets/:datasetId/routines")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines")

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/projects/:projectId/datasets/:datasetId/routines') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines";

    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}}/projects/:projectId/datasets/:datasetId/routines
http GET {{baseUrl}}/projects/:projectId/datasets/:datasetId/routines
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/routines
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

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

dataTask.resume()
PUT bigquery.routines.update
{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId
QUERY PARAMS

projectId
datasetId
routineId
BODY json

{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}");

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

(client/put "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId" {:content-type :json
                                                                                                       :form-params {:arguments [{:argumentKind ""
                                                                                                                                  :dataType {:arrayElementType ""
                                                                                                                                             :structType {:fields []}
                                                                                                                                             :typeKind ""}
                                                                                                                                  :mode ""
                                                                                                                                  :name ""}]
                                                                                                                     :creationTime ""
                                                                                                                     :definitionBody ""
                                                                                                                     :description ""
                                                                                                                     :determinismLevel ""
                                                                                                                     :etag ""
                                                                                                                     :importedLibraries []
                                                                                                                     :language ""
                                                                                                                     :lastModifiedTime ""
                                                                                                                     :remoteFunctionOptions {:connection ""
                                                                                                                                             :endpoint ""
                                                                                                                                             :maxBatchingRows ""
                                                                                                                                             :userDefinedContext {}}
                                                                                                                     :returnTableType {:columns [{:name ""
                                                                                                                                                  :type {}}]}
                                                                                                                     :returnType {}
                                                                                                                     :routineReference {:datasetId ""
                                                                                                                                        :projectId ""
                                                                                                                                        :routineId ""}
                                                                                                                     :routineType ""
                                                                                                                     :sparkOptions {:archiveUris []
                                                                                                                                    :connection ""
                                                                                                                                    :containerImage ""
                                                                                                                                    :fileUris []
                                                                                                                                    :jarUris []
                                                                                                                                    :mainClass ""
                                                                                                                                    :mainFileUri ""
                                                                                                                                    :properties {}
                                                                                                                                    :pyFileUris []
                                                                                                                                    :runtimeVersion ""}
                                                                                                                     :strictMode false}})
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"),
    Content = new StringContent("{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": 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}}/projects/:projectId/datasets/:datasetId/routines/:routineId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"

	payload := strings.NewReader("{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}")

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

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

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

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

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

}
PUT /baseUrl/projects/:projectId/datasets/:datasetId/routines/:routineId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1058

{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": 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  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .header("content-type", "application/json")
  .body("{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}")
  .asString();
const data = JSON.stringify({
  arguments: [
    {
      argumentKind: '',
      dataType: {
        arrayElementType: '',
        structType: {
          fields: []
        },
        typeKind: ''
      },
      mode: '',
      name: ''
    }
  ],
  creationTime: '',
  definitionBody: '',
  description: '',
  determinismLevel: '',
  etag: '',
  importedLibraries: [],
  language: '',
  lastModifiedTime: '',
  remoteFunctionOptions: {
    connection: '',
    endpoint: '',
    maxBatchingRows: '',
    userDefinedContext: {}
  },
  returnTableType: {
    columns: [
      {
        name: '',
        type: {}
      }
    ]
  },
  returnType: {},
  routineReference: {
    datasetId: '',
    projectId: '',
    routineId: ''
  },
  routineType: '',
  sparkOptions: {
    archiveUris: [],
    connection: '',
    containerImage: '',
    fileUris: [],
    jarUris: [],
    mainClass: '',
    mainFileUri: '',
    properties: {},
    pyFileUris: [],
    runtimeVersion: ''
  },
  strictMode: false
});

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

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

xhr.open('PUT', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId',
  headers: {'content-type': 'application/json'},
  data: {
    arguments: [
      {
        argumentKind: '',
        dataType: {arrayElementType: '', structType: {fields: []}, typeKind: ''},
        mode: '',
        name: ''
      }
    ],
    creationTime: '',
    definitionBody: '',
    description: '',
    determinismLevel: '',
    etag: '',
    importedLibraries: [],
    language: '',
    lastModifiedTime: '',
    remoteFunctionOptions: {connection: '', endpoint: '', maxBatchingRows: '', userDefinedContext: {}},
    returnTableType: {columns: [{name: '', type: {}}]},
    returnType: {},
    routineReference: {datasetId: '', projectId: '', routineId: ''},
    routineType: '',
    sparkOptions: {
      archiveUris: [],
      connection: '',
      containerImage: '',
      fileUris: [],
      jarUris: [],
      mainClass: '',
      mainFileUri: '',
      properties: {},
      pyFileUris: [],
      runtimeVersion: ''
    },
    strictMode: false
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"arguments":[{"argumentKind":"","dataType":{"arrayElementType":"","structType":{"fields":[]},"typeKind":""},"mode":"","name":""}],"creationTime":"","definitionBody":"","description":"","determinismLevel":"","etag":"","importedLibraries":[],"language":"","lastModifiedTime":"","remoteFunctionOptions":{"connection":"","endpoint":"","maxBatchingRows":"","userDefinedContext":{}},"returnTableType":{"columns":[{"name":"","type":{}}]},"returnType":{},"routineReference":{"datasetId":"","projectId":"","routineId":""},"routineType":"","sparkOptions":{"archiveUris":[],"connection":"","containerImage":"","fileUris":[],"jarUris":[],"mainClass":"","mainFileUri":"","properties":{},"pyFileUris":[],"runtimeVersion":""},"strictMode":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}}/projects/:projectId/datasets/:datasetId/routines/:routineId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "arguments": [\n    {\n      "argumentKind": "",\n      "dataType": {\n        "arrayElementType": "",\n        "structType": {\n          "fields": []\n        },\n        "typeKind": ""\n      },\n      "mode": "",\n      "name": ""\n    }\n  ],\n  "creationTime": "",\n  "definitionBody": "",\n  "description": "",\n  "determinismLevel": "",\n  "etag": "",\n  "importedLibraries": [],\n  "language": "",\n  "lastModifiedTime": "",\n  "remoteFunctionOptions": {\n    "connection": "",\n    "endpoint": "",\n    "maxBatchingRows": "",\n    "userDefinedContext": {}\n  },\n  "returnTableType": {\n    "columns": [\n      {\n        "name": "",\n        "type": {}\n      }\n    ]\n  },\n  "returnType": {},\n  "routineReference": {\n    "datasetId": "",\n    "projectId": "",\n    "routineId": ""\n  },\n  "routineType": "",\n  "sparkOptions": {\n    "archiveUris": [],\n    "connection": "",\n    "containerImage": "",\n    "fileUris": [],\n    "jarUris": [],\n    "mainClass": "",\n    "mainFileUri": "",\n    "properties": {},\n    "pyFileUris": [],\n    "runtimeVersion": ""\n  },\n  "strictMode": 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  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/routines/:routineId',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  arguments: [
    {
      argumentKind: '',
      dataType: {arrayElementType: '', structType: {fields: []}, typeKind: ''},
      mode: '',
      name: ''
    }
  ],
  creationTime: '',
  definitionBody: '',
  description: '',
  determinismLevel: '',
  etag: '',
  importedLibraries: [],
  language: '',
  lastModifiedTime: '',
  remoteFunctionOptions: {connection: '', endpoint: '', maxBatchingRows: '', userDefinedContext: {}},
  returnTableType: {columns: [{name: '', type: {}}]},
  returnType: {},
  routineReference: {datasetId: '', projectId: '', routineId: ''},
  routineType: '',
  sparkOptions: {
    archiveUris: [],
    connection: '',
    containerImage: '',
    fileUris: [],
    jarUris: [],
    mainClass: '',
    mainFileUri: '',
    properties: {},
    pyFileUris: [],
    runtimeVersion: ''
  },
  strictMode: false
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId',
  headers: {'content-type': 'application/json'},
  body: {
    arguments: [
      {
        argumentKind: '',
        dataType: {arrayElementType: '', structType: {fields: []}, typeKind: ''},
        mode: '',
        name: ''
      }
    ],
    creationTime: '',
    definitionBody: '',
    description: '',
    determinismLevel: '',
    etag: '',
    importedLibraries: [],
    language: '',
    lastModifiedTime: '',
    remoteFunctionOptions: {connection: '', endpoint: '', maxBatchingRows: '', userDefinedContext: {}},
    returnTableType: {columns: [{name: '', type: {}}]},
    returnType: {},
    routineReference: {datasetId: '', projectId: '', routineId: ''},
    routineType: '',
    sparkOptions: {
      archiveUris: [],
      connection: '',
      containerImage: '',
      fileUris: [],
      jarUris: [],
      mainClass: '',
      mainFileUri: '',
      properties: {},
      pyFileUris: [],
      runtimeVersion: ''
    },
    strictMode: false
  },
  json: true
};

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

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

const req = unirest('PUT', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId');

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

req.type('json');
req.send({
  arguments: [
    {
      argumentKind: '',
      dataType: {
        arrayElementType: '',
        structType: {
          fields: []
        },
        typeKind: ''
      },
      mode: '',
      name: ''
    }
  ],
  creationTime: '',
  definitionBody: '',
  description: '',
  determinismLevel: '',
  etag: '',
  importedLibraries: [],
  language: '',
  lastModifiedTime: '',
  remoteFunctionOptions: {
    connection: '',
    endpoint: '',
    maxBatchingRows: '',
    userDefinedContext: {}
  },
  returnTableType: {
    columns: [
      {
        name: '',
        type: {}
      }
    ]
  },
  returnType: {},
  routineReference: {
    datasetId: '',
    projectId: '',
    routineId: ''
  },
  routineType: '',
  sparkOptions: {
    archiveUris: [],
    connection: '',
    containerImage: '',
    fileUris: [],
    jarUris: [],
    mainClass: '',
    mainFileUri: '',
    properties: {},
    pyFileUris: [],
    runtimeVersion: ''
  },
  strictMode: false
});

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId',
  headers: {'content-type': 'application/json'},
  data: {
    arguments: [
      {
        argumentKind: '',
        dataType: {arrayElementType: '', structType: {fields: []}, typeKind: ''},
        mode: '',
        name: ''
      }
    ],
    creationTime: '',
    definitionBody: '',
    description: '',
    determinismLevel: '',
    etag: '',
    importedLibraries: [],
    language: '',
    lastModifiedTime: '',
    remoteFunctionOptions: {connection: '', endpoint: '', maxBatchingRows: '', userDefinedContext: {}},
    returnTableType: {columns: [{name: '', type: {}}]},
    returnType: {},
    routineReference: {datasetId: '', projectId: '', routineId: ''},
    routineType: '',
    sparkOptions: {
      archiveUris: [],
      connection: '',
      containerImage: '',
      fileUris: [],
      jarUris: [],
      mainClass: '',
      mainFileUri: '',
      properties: {},
      pyFileUris: [],
      runtimeVersion: ''
    },
    strictMode: false
  }
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"arguments":[{"argumentKind":"","dataType":{"arrayElementType":"","structType":{"fields":[]},"typeKind":""},"mode":"","name":""}],"creationTime":"","definitionBody":"","description":"","determinismLevel":"","etag":"","importedLibraries":[],"language":"","lastModifiedTime":"","remoteFunctionOptions":{"connection":"","endpoint":"","maxBatchingRows":"","userDefinedContext":{}},"returnTableType":{"columns":[{"name":"","type":{}}]},"returnType":{},"routineReference":{"datasetId":"","projectId":"","routineId":""},"routineType":"","sparkOptions":{"archiveUris":[],"connection":"","containerImage":"","fileUris":[],"jarUris":[],"mainClass":"","mainFileUri":"","properties":{},"pyFileUris":[],"runtimeVersion":""},"strictMode":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 = @{ @"arguments": @[ @{ @"argumentKind": @"", @"dataType": @{ @"arrayElementType": @"", @"structType": @{ @"fields": @[  ] }, @"typeKind": @"" }, @"mode": @"", @"name": @"" } ],
                              @"creationTime": @"",
                              @"definitionBody": @"",
                              @"description": @"",
                              @"determinismLevel": @"",
                              @"etag": @"",
                              @"importedLibraries": @[  ],
                              @"language": @"",
                              @"lastModifiedTime": @"",
                              @"remoteFunctionOptions": @{ @"connection": @"", @"endpoint": @"", @"maxBatchingRows": @"", @"userDefinedContext": @{  } },
                              @"returnTableType": @{ @"columns": @[ @{ @"name": @"", @"type": @{  } } ] },
                              @"returnType": @{  },
                              @"routineReference": @{ @"datasetId": @"", @"projectId": @"", @"routineId": @"" },
                              @"routineType": @"",
                              @"sparkOptions": @{ @"archiveUris": @[  ], @"connection": @"", @"containerImage": @"", @"fileUris": @[  ], @"jarUris": @[  ], @"mainClass": @"", @"mainFileUri": @"", @"properties": @{  }, @"pyFileUris": @[  ], @"runtimeVersion": @"" },
                              @"strictMode": @NO };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

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

let uri = Uri.of_string "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'arguments' => [
        [
                'argumentKind' => '',
                'dataType' => [
                                'arrayElementType' => '',
                                'structType' => [
                                                                'fields' => [
                                                                                                                                
                                                                ]
                                ],
                                'typeKind' => ''
                ],
                'mode' => '',
                'name' => ''
        ]
    ],
    'creationTime' => '',
    'definitionBody' => '',
    'description' => '',
    'determinismLevel' => '',
    'etag' => '',
    'importedLibraries' => [
        
    ],
    'language' => '',
    'lastModifiedTime' => '',
    'remoteFunctionOptions' => [
        'connection' => '',
        'endpoint' => '',
        'maxBatchingRows' => '',
        'userDefinedContext' => [
                
        ]
    ],
    'returnTableType' => [
        'columns' => [
                [
                                'name' => '',
                                'type' => [
                                                                
                                ]
                ]
        ]
    ],
    'returnType' => [
        
    ],
    'routineReference' => [
        'datasetId' => '',
        'projectId' => '',
        'routineId' => ''
    ],
    'routineType' => '',
    'sparkOptions' => [
        'archiveUris' => [
                
        ],
        'connection' => '',
        'containerImage' => '',
        'fileUris' => [
                
        ],
        'jarUris' => [
                
        ],
        'mainClass' => '',
        'mainFileUri' => '',
        'properties' => [
                
        ],
        'pyFileUris' => [
                
        ],
        'runtimeVersion' => ''
    ],
    'strictMode' => null
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId', [
  'body' => '{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId');
$request->setMethod(HTTP_METH_PUT);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'arguments' => [
    [
        'argumentKind' => '',
        'dataType' => [
                'arrayElementType' => '',
                'structType' => [
                                'fields' => [
                                                                
                                ]
                ],
                'typeKind' => ''
        ],
        'mode' => '',
        'name' => ''
    ]
  ],
  'creationTime' => '',
  'definitionBody' => '',
  'description' => '',
  'determinismLevel' => '',
  'etag' => '',
  'importedLibraries' => [
    
  ],
  'language' => '',
  'lastModifiedTime' => '',
  'remoteFunctionOptions' => [
    'connection' => '',
    'endpoint' => '',
    'maxBatchingRows' => '',
    'userDefinedContext' => [
        
    ]
  ],
  'returnTableType' => [
    'columns' => [
        [
                'name' => '',
                'type' => [
                                
                ]
        ]
    ]
  ],
  'returnType' => [
    
  ],
  'routineReference' => [
    'datasetId' => '',
    'projectId' => '',
    'routineId' => ''
  ],
  'routineType' => '',
  'sparkOptions' => [
    'archiveUris' => [
        
    ],
    'connection' => '',
    'containerImage' => '',
    'fileUris' => [
        
    ],
    'jarUris' => [
        
    ],
    'mainClass' => '',
    'mainFileUri' => '',
    'properties' => [
        
    ],
    'pyFileUris' => [
        
    ],
    'runtimeVersion' => ''
  ],
  'strictMode' => null
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'arguments' => [
    [
        'argumentKind' => '',
        'dataType' => [
                'arrayElementType' => '',
                'structType' => [
                                'fields' => [
                                                                
                                ]
                ],
                'typeKind' => ''
        ],
        'mode' => '',
        'name' => ''
    ]
  ],
  'creationTime' => '',
  'definitionBody' => '',
  'description' => '',
  'determinismLevel' => '',
  'etag' => '',
  'importedLibraries' => [
    
  ],
  'language' => '',
  'lastModifiedTime' => '',
  'remoteFunctionOptions' => [
    'connection' => '',
    'endpoint' => '',
    'maxBatchingRows' => '',
    'userDefinedContext' => [
        
    ]
  ],
  'returnTableType' => [
    'columns' => [
        [
                'name' => '',
                'type' => [
                                
                ]
        ]
    ]
  ],
  'returnType' => [
    
  ],
  'routineReference' => [
    'datasetId' => '',
    'projectId' => '',
    'routineId' => ''
  ],
  'routineType' => '',
  'sparkOptions' => [
    'archiveUris' => [
        
    ],
    'connection' => '',
    'containerImage' => '',
    'fileUris' => [
        
    ],
    'jarUris' => [
        
    ],
    'mainClass' => '',
    'mainFileUri' => '',
    'properties' => [
        
    ],
    'pyFileUris' => [
        
    ],
    'runtimeVersion' => ''
  ],
  'strictMode' => null
]));
$request->setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId');
$request->setRequestMethod('PUT');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}'
import http.client

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

payload = "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}"

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

conn.request("PUT", "/baseUrl/projects/:projectId/datasets/:datasetId/routines/:routineId", payload, headers)

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"

payload = {
    "arguments": [
        {
            "argumentKind": "",
            "dataType": {
                "arrayElementType": "",
                "structType": { "fields": [] },
                "typeKind": ""
            },
            "mode": "",
            "name": ""
        }
    ],
    "creationTime": "",
    "definitionBody": "",
    "description": "",
    "determinismLevel": "",
    "etag": "",
    "importedLibraries": [],
    "language": "",
    "lastModifiedTime": "",
    "remoteFunctionOptions": {
        "connection": "",
        "endpoint": "",
        "maxBatchingRows": "",
        "userDefinedContext": {}
    },
    "returnTableType": { "columns": [
            {
                "name": "",
                "type": {}
            }
        ] },
    "returnType": {},
    "routineReference": {
        "datasetId": "",
        "projectId": "",
        "routineId": ""
    },
    "routineType": "",
    "sparkOptions": {
        "archiveUris": [],
        "connection": "",
        "containerImage": "",
        "fileUris": [],
        "jarUris": [],
        "mainClass": "",
        "mainFileUri": "",
        "properties": {},
        "pyFileUris": [],
        "runtimeVersion": ""
    },
    "strictMode": False
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId"

payload <- "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")

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

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}"

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

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

response = conn.put('/baseUrl/projects/:projectId/datasets/:datasetId/routines/:routineId') do |req|
  req.body = "{\n  \"arguments\": [\n    {\n      \"argumentKind\": \"\",\n      \"dataType\": {\n        \"arrayElementType\": \"\",\n        \"structType\": {\n          \"fields\": []\n        },\n        \"typeKind\": \"\"\n      },\n      \"mode\": \"\",\n      \"name\": \"\"\n    }\n  ],\n  \"creationTime\": \"\",\n  \"definitionBody\": \"\",\n  \"description\": \"\",\n  \"determinismLevel\": \"\",\n  \"etag\": \"\",\n  \"importedLibraries\": [],\n  \"language\": \"\",\n  \"lastModifiedTime\": \"\",\n  \"remoteFunctionOptions\": {\n    \"connection\": \"\",\n    \"endpoint\": \"\",\n    \"maxBatchingRows\": \"\",\n    \"userDefinedContext\": {}\n  },\n  \"returnTableType\": {\n    \"columns\": [\n      {\n        \"name\": \"\",\n        \"type\": {}\n      }\n    ]\n  },\n  \"returnType\": {},\n  \"routineReference\": {\n    \"datasetId\": \"\",\n    \"projectId\": \"\",\n    \"routineId\": \"\"\n  },\n  \"routineType\": \"\",\n  \"sparkOptions\": {\n    \"archiveUris\": [],\n    \"connection\": \"\",\n    \"containerImage\": \"\",\n    \"fileUris\": [],\n    \"jarUris\": [],\n    \"mainClass\": \"\",\n    \"mainFileUri\": \"\",\n    \"properties\": {},\n    \"pyFileUris\": [],\n    \"runtimeVersion\": \"\"\n  },\n  \"strictMode\": false\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId";

    let payload = json!({
        "arguments": (
            json!({
                "argumentKind": "",
                "dataType": json!({
                    "arrayElementType": "",
                    "structType": json!({"fields": ()}),
                    "typeKind": ""
                }),
                "mode": "",
                "name": ""
            })
        ),
        "creationTime": "",
        "definitionBody": "",
        "description": "",
        "determinismLevel": "",
        "etag": "",
        "importedLibraries": (),
        "language": "",
        "lastModifiedTime": "",
        "remoteFunctionOptions": json!({
            "connection": "",
            "endpoint": "",
            "maxBatchingRows": "",
            "userDefinedContext": json!({})
        }),
        "returnTableType": json!({"columns": (
                json!({
                    "name": "",
                    "type": json!({})
                })
            )}),
        "returnType": json!({}),
        "routineReference": json!({
            "datasetId": "",
            "projectId": "",
            "routineId": ""
        }),
        "routineType": "",
        "sparkOptions": json!({
            "archiveUris": (),
            "connection": "",
            "containerImage": "",
            "fileUris": (),
            "jarUris": (),
            "mainClass": "",
            "mainFileUri": "",
            "properties": json!({}),
            "pyFileUris": (),
            "runtimeVersion": ""
        }),
        "strictMode": false
    });

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId \
  --header 'content-type: application/json' \
  --data '{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}'
echo '{
  "arguments": [
    {
      "argumentKind": "",
      "dataType": {
        "arrayElementType": "",
        "structType": {
          "fields": []
        },
        "typeKind": ""
      },
      "mode": "",
      "name": ""
    }
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": {
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": {}
  },
  "returnTableType": {
    "columns": [
      {
        "name": "",
        "type": {}
      }
    ]
  },
  "returnType": {},
  "routineReference": {
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  },
  "routineType": "",
  "sparkOptions": {
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": {},
    "pyFileUris": [],
    "runtimeVersion": ""
  },
  "strictMode": false
}' |  \
  http PUT {{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "arguments": [\n    {\n      "argumentKind": "",\n      "dataType": {\n        "arrayElementType": "",\n        "structType": {\n          "fields": []\n        },\n        "typeKind": ""\n      },\n      "mode": "",\n      "name": ""\n    }\n  ],\n  "creationTime": "",\n  "definitionBody": "",\n  "description": "",\n  "determinismLevel": "",\n  "etag": "",\n  "importedLibraries": [],\n  "language": "",\n  "lastModifiedTime": "",\n  "remoteFunctionOptions": {\n    "connection": "",\n    "endpoint": "",\n    "maxBatchingRows": "",\n    "userDefinedContext": {}\n  },\n  "returnTableType": {\n    "columns": [\n      {\n        "name": "",\n        "type": {}\n      }\n    ]\n  },\n  "returnType": {},\n  "routineReference": {\n    "datasetId": "",\n    "projectId": "",\n    "routineId": ""\n  },\n  "routineType": "",\n  "sparkOptions": {\n    "archiveUris": [],\n    "connection": "",\n    "containerImage": "",\n    "fileUris": [],\n    "jarUris": [],\n    "mainClass": "",\n    "mainFileUri": "",\n    "properties": {},\n    "pyFileUris": [],\n    "runtimeVersion": ""\n  },\n  "strictMode": false\n}' \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "arguments": [
    [
      "argumentKind": "",
      "dataType": [
        "arrayElementType": "",
        "structType": ["fields": []],
        "typeKind": ""
      ],
      "mode": "",
      "name": ""
    ]
  ],
  "creationTime": "",
  "definitionBody": "",
  "description": "",
  "determinismLevel": "",
  "etag": "",
  "importedLibraries": [],
  "language": "",
  "lastModifiedTime": "",
  "remoteFunctionOptions": [
    "connection": "",
    "endpoint": "",
    "maxBatchingRows": "",
    "userDefinedContext": []
  ],
  "returnTableType": ["columns": [
      [
        "name": "",
        "type": []
      ]
    ]],
  "returnType": [],
  "routineReference": [
    "datasetId": "",
    "projectId": "",
    "routineId": ""
  ],
  "routineType": "",
  "sparkOptions": [
    "archiveUris": [],
    "connection": "",
    "containerImage": "",
    "fileUris": [],
    "jarUris": [],
    "mainClass": "",
    "mainFileUri": "",
    "properties": [],
    "pyFileUris": [],
    "runtimeVersion": ""
  ],
  "strictMode": false
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/routines/:routineId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
GET bigquery.rowAccessPolicies.list
{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies
QUERY PARAMS

projectId
datasetId
tableId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies");

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

(client/get "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies"

	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/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies"))
    .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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies")
  .asString();
const 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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies';
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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies',
  method: 'GET',
  headers: {}
};

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies'
};

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

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

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies');

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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies'
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies';
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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies"]
                                                       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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies",
  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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies');

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies")

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/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies";

    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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies
http GET {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/rowAccessPolicies")! 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 bigquery.tabledata.insertAll
{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll
QUERY PARAMS

projectId
datasetId
tableId
BODY json

{
  "ignoreUnknownValues": false,
  "kind": "",
  "rows": [
    {
      "insertId": "",
      "json": {}
    }
  ],
  "skipInvalidRows": false,
  "templateSuffix": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}");

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

(client/post "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll" {:content-type :json
                                                                                                              :form-params {:ignoreUnknownValues false
                                                                                                                            :kind ""
                                                                                                                            :rows [{:insertId ""
                                                                                                                                    :json {}}]
                                                                                                                            :skipInvalidRows false
                                                                                                                            :templateSuffix ""}})
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll"),
    Content = new StringContent("{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll"

	payload := strings.NewReader("{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\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/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 168

{
  "ignoreUnknownValues": false,
  "kind": "",
  "rows": [
    {
      "insertId": "",
      "json": {}
    }
  ],
  "skipInvalidRows": false,
  "templateSuffix": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll")
  .header("content-type", "application/json")
  .body("{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  ignoreUnknownValues: false,
  kind: '',
  rows: [
    {
      insertId: '',
      json: {}
    }
  ],
  skipInvalidRows: false,
  templateSuffix: ''
});

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

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

xhr.open('POST', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll',
  headers: {'content-type': 'application/json'},
  data: {
    ignoreUnknownValues: false,
    kind: '',
    rows: [{insertId: '', json: {}}],
    skipInvalidRows: false,
    templateSuffix: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"ignoreUnknownValues":false,"kind":"","rows":[{"insertId":"","json":{}}],"skipInvalidRows":false,"templateSuffix":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "ignoreUnknownValues": false,\n  "kind": "",\n  "rows": [\n    {\n      "insertId": "",\n      "json": {}\n    }\n  ],\n  "skipInvalidRows": false,\n  "templateSuffix": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll")
  .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/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  ignoreUnknownValues: false,
  kind: '',
  rows: [{insertId: '', json: {}}],
  skipInvalidRows: false,
  templateSuffix: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll',
  headers: {'content-type': 'application/json'},
  body: {
    ignoreUnknownValues: false,
    kind: '',
    rows: [{insertId: '', json: {}}],
    skipInvalidRows: false,
    templateSuffix: ''
  },
  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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll');

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

req.type('json');
req.send({
  ignoreUnknownValues: false,
  kind: '',
  rows: [
    {
      insertId: '',
      json: {}
    }
  ],
  skipInvalidRows: false,
  templateSuffix: ''
});

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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll',
  headers: {'content-type': 'application/json'},
  data: {
    ignoreUnknownValues: false,
    kind: '',
    rows: [{insertId: '', json: {}}],
    skipInvalidRows: false,
    templateSuffix: ''
  }
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"ignoreUnknownValues":false,"kind":"","rows":[{"insertId":"","json":{}}],"skipInvalidRows":false,"templateSuffix":""}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"ignoreUnknownValues": @NO,
                              @"kind": @"",
                              @"rows": @[ @{ @"insertId": @"", @"json": @{  } } ],
                              @"skipInvalidRows": @NO,
                              @"templateSuffix": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll"]
                                                       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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll",
  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([
    'ignoreUnknownValues' => null,
    'kind' => '',
    'rows' => [
        [
                'insertId' => '',
                'json' => [
                                
                ]
        ]
    ],
    'skipInvalidRows' => null,
    'templateSuffix' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll', [
  'body' => '{
  "ignoreUnknownValues": false,
  "kind": "",
  "rows": [
    {
      "insertId": "",
      "json": {}
    }
  ],
  "skipInvalidRows": false,
  "templateSuffix": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'ignoreUnknownValues' => null,
  'kind' => '',
  'rows' => [
    [
        'insertId' => '',
        'json' => [
                
        ]
    ]
  ],
  'skipInvalidRows' => null,
  'templateSuffix' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'ignoreUnknownValues' => null,
  'kind' => '',
  'rows' => [
    [
        'insertId' => '',
        'json' => [
                
        ]
    ]
  ],
  'skipInvalidRows' => null,
  'templateSuffix' => ''
]));
$request->setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll');
$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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "ignoreUnknownValues": false,
  "kind": "",
  "rows": [
    {
      "insertId": "",
      "json": {}
    }
  ],
  "skipInvalidRows": false,
  "templateSuffix": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "ignoreUnknownValues": false,
  "kind": "",
  "rows": [
    {
      "insertId": "",
      "json": {}
    }
  ],
  "skipInvalidRows": false,
  "templateSuffix": ""
}'
import http.client

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

payload = "{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}"

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

conn.request("POST", "/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll", payload, headers)

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll"

payload = {
    "ignoreUnknownValues": False,
    "kind": "",
    "rows": [
        {
            "insertId": "",
            "json": {}
        }
    ],
    "skipInvalidRows": False,
    "templateSuffix": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll"

payload <- "{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll")

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  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}"

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/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll') do |req|
  req.body = "{\n  \"ignoreUnknownValues\": false,\n  \"kind\": \"\",\n  \"rows\": [\n    {\n      \"insertId\": \"\",\n      \"json\": {}\n    }\n  ],\n  \"skipInvalidRows\": false,\n  \"templateSuffix\": \"\"\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll";

    let payload = json!({
        "ignoreUnknownValues": false,
        "kind": "",
        "rows": (
            json!({
                "insertId": "",
                "json": json!({})
            })
        ),
        "skipInvalidRows": false,
        "templateSuffix": ""
    });

    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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll \
  --header 'content-type: application/json' \
  --data '{
  "ignoreUnknownValues": false,
  "kind": "",
  "rows": [
    {
      "insertId": "",
      "json": {}
    }
  ],
  "skipInvalidRows": false,
  "templateSuffix": ""
}'
echo '{
  "ignoreUnknownValues": false,
  "kind": "",
  "rows": [
    {
      "insertId": "",
      "json": {}
    }
  ],
  "skipInvalidRows": false,
  "templateSuffix": ""
}' |  \
  http POST {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "ignoreUnknownValues": false,\n  "kind": "",\n  "rows": [\n    {\n      "insertId": "",\n      "json": {}\n    }\n  ],\n  "skipInvalidRows": false,\n  "templateSuffix": ""\n}' \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "ignoreUnknownValues": false,
  "kind": "",
  "rows": [
    [
      "insertId": "",
      "json": []
    ]
  ],
  "skipInvalidRows": false,
  "templateSuffix": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/insertAll")! 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 bigquery.tabledata.list
{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data
QUERY PARAMS

projectId
datasetId
tableId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data");

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

(client/get "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data"

	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/projects/:projectId/datasets/:datasetId/tables/:tableId/data HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data"))
    .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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data")
  .asString();
const 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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId/data',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data'
};

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

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

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data');

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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data'
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data';
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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data"]
                                                       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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data",
  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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data');

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId/data")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data")

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/projects/:projectId/datasets/:datasetId/tables/:tableId/data') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data";

    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}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data
http GET {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId/data")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

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

dataTask.resume()
DELETE bigquery.tables.delete
{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId
QUERY PARAMS

projectId
datasetId
tableId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId");

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

(client/delete "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

	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/projects/:projectId/datasets/:datasetId/tables/:tableId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"))
    .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}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .asString();
const 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}}/projects/:projectId/datasets/:datasetId/tables/:tableId');

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

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .delete(null)
  .build()

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

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId/tables/:tableId'
};

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

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

const req = unirest('DELETE', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');

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}}/projects/:projectId/datasets/:datasetId/tables/:tableId'
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId';
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}}/projects/:projectId/datasets/:datasetId/tables/:tableId"]
                                                       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}}/projects/:projectId/datasets/:datasetId/tables/:tableId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');
$request->setMethod(HTTP_METH_DELETE);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId' -Method DELETE 
import http.client

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

conn.request("DELETE", "/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

response = requests.delete(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")

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/projects/:projectId/datasets/:datasetId/tables/:tableId') do |req|
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId";

    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}}/projects/:projectId/datasets/:datasetId/tables/:tableId
http DELETE {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")! 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 bigquery.tables.get
{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId
QUERY PARAMS

projectId
datasetId
tableId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId");

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

(client/get "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

	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/projects/:projectId/datasets/:datasetId/tables/:tableId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"))
    .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}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .asString();
const 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}}/projects/:projectId/datasets/:datasetId/tables/:tableId');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId',
  headers: {}
};

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

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId/tables/:tableId'
};

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

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

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');

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}}/projects/:projectId/datasets/:datasetId/tables/:tableId'
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId';
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}}/projects/:projectId/datasets/:datasetId/tables/:tableId"]
                                                       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}}/projects/:projectId/datasets/:datasetId/tables/:tableId" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId")

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

response = requests.get(url)

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

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

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

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")

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/projects/:projectId/datasets/:datasetId/tables/:tableId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId";

    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}}/projects/:projectId/datasets/:datasetId/tables/:tableId
http GET {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")! 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 bigquery.tables.getIamPolicy
{{baseUrl}}/:resource:getIamPolicy
QUERY PARAMS

resource
BODY json

{
  "options": {
    "requestedPolicyVersion": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/:resource:getIamPolicy");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}");

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

(client/post "{{baseUrl}}/:resource:getIamPolicy" {:content-type :json
                                                                   :form-params {:options {:requestedPolicyVersion 0}}})
require "http/client"

url = "{{baseUrl}}/:resource:getIamPolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}"

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

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

func main() {

	url := "{{baseUrl}}/:resource:getIamPolicy"

	payload := strings.NewReader("{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/:resource:getIamPolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 54

{
  "options": {
    "requestedPolicyVersion": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/:resource:getIamPolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/:resource:getIamPolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/:resource:getIamPolicy")
  .header("content-type", "application/json")
  .body("{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  options: {
    requestedPolicyVersion: 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}}/:resource:getIamPolicy');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/:resource:getIamPolicy',
  headers: {'content-type': 'application/json'},
  data: {options: {requestedPolicyVersion: 0}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/:resource:getIamPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"options":{"requestedPolicyVersion":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}}/:resource:getIamPolicy',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "options": {\n    "requestedPolicyVersion": 0\n  }\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/:resource:getIamPolicy")
  .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/:resource:getIamPolicy',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/:resource:getIamPolicy',
  headers: {'content-type': 'application/json'},
  body: {options: {requestedPolicyVersion: 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}}/:resource:getIamPolicy');

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

req.type('json');
req.send({
  options: {
    requestedPolicyVersion: 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}}/:resource:getIamPolicy',
  headers: {'content-type': 'application/json'},
  data: {options: {requestedPolicyVersion: 0}}
};

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

const url = '{{baseUrl}}/:resource:getIamPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"options":{"requestedPolicyVersion":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 = @{ @"options": @{ @"requestedPolicyVersion": @0 } };

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

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

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

echo $response->getBody();
setUrl('{{baseUrl}}/:resource:getIamPolicy');
$request->setMethod(HTTP_METH_POST);

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

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

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

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

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

payload = "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}"

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

conn.request("POST", "/baseUrl/:resource:getIamPolicy", payload, headers)

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

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

url = "{{baseUrl}}/:resource:getIamPolicy"

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

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

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

url <- "{{baseUrl}}/:resource:getIamPolicy"

payload <- "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/:resource:getIamPolicy")

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  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}"

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

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

response = conn.post('/baseUrl/:resource:getIamPolicy') do |req|
  req.body = "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}"
end

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

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

    let payload = json!({"options": json!({"requestedPolicyVersion": 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}}/:resource:getIamPolicy \
  --header 'content-type: application/json' \
  --data '{
  "options": {
    "requestedPolicyVersion": 0
  }
}'
echo '{
  "options": {
    "requestedPolicyVersion": 0
  }
}' |  \
  http POST {{baseUrl}}/:resource:getIamPolicy \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "options": {\n    "requestedPolicyVersion": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/:resource:getIamPolicy
import Foundation

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/:resource:getIamPolicy")! 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 bigquery.tables.insert
{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables
QUERY PARAMS

projectId
datasetId
BODY json

{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}");

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

(client/post "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables" {:content-type :json
                                                                                           :form-params {:cloneDefinition {:baseTableReference {:datasetId ""
                                                                                                                                                :projectId ""
                                                                                                                                                :tableId ""}
                                                                                                                           :cloneTime ""}
                                                                                                         :clustering {:fields []}
                                                                                                         :creationTime ""
                                                                                                         :defaultCollation ""
                                                                                                         :defaultRoundingMode ""
                                                                                                         :description ""
                                                                                                         :encryptionConfiguration {:kmsKeyName ""}
                                                                                                         :etag ""
                                                                                                         :expirationTime ""
                                                                                                         :externalDataConfiguration {:autodetect false
                                                                                                                                     :avroOptions {:useAvroLogicalTypes false}
                                                                                                                                     :bigtableOptions {:columnFamilies [{:columns [{:encoding ""
                                                                                                                                                                                    :fieldName ""
                                                                                                                                                                                    :onlyReadLatest false
                                                                                                                                                                                    :qualifierEncoded ""
                                                                                                                                                                                    :qualifierString ""
                                                                                                                                                                                    :type ""}]
                                                                                                                                                                         :encoding ""
                                                                                                                                                                         :familyId ""
                                                                                                                                                                         :onlyReadLatest false
                                                                                                                                                                         :type ""}]
                                                                                                                                                       :ignoreUnspecifiedColumnFamilies false
                                                                                                                                                       :readRowkeyAsString false}
                                                                                                                                     :compression ""
                                                                                                                                     :connectionId ""
                                                                                                                                     :csvOptions {:allowJaggedRows false
                                                                                                                                                  :allowQuotedNewlines false
                                                                                                                                                  :encoding ""
                                                                                                                                                  :fieldDelimiter ""
                                                                                                                                                  :null_marker ""
                                                                                                                                                  :preserveAsciiControlCharacters false
                                                                                                                                                  :quote ""
                                                                                                                                                  :skipLeadingRows ""}
                                                                                                                                     :decimalTargetTypes []
                                                                                                                                     :googleSheetsOptions {:range ""
                                                                                                                                                           :skipLeadingRows ""}
                                                                                                                                     :hivePartitioningOptions {:mode ""
                                                                                                                                                               :requirePartitionFilter false
                                                                                                                                                               :sourceUriPrefix ""}
                                                                                                                                     :ignoreUnknownValues false
                                                                                                                                     :maxBadRecords 0
                                                                                                                                     :metadataCacheMode ""
                                                                                                                                     :objectMetadata ""
                                                                                                                                     :parquetOptions {:enableListInference false
                                                                                                                                                      :enumAsString false}
                                                                                                                                     :referenceFileSchemaUri ""
                                                                                                                                     :schema {:fields [{:categories {:names []}
                                                                                                                                                        :collation ""
                                                                                                                                                        :defaultValueExpression ""
                                                                                                                                                        :description ""
                                                                                                                                                        :fields []
                                                                                                                                                        :maxLength ""
                                                                                                                                                        :mode ""
                                                                                                                                                        :name ""
                                                                                                                                                        :policyTags {:names []}
                                                                                                                                                        :precision ""
                                                                                                                                                        :roundingMode ""
                                                                                                                                                        :scale ""
                                                                                                                                                        :type ""}]}
                                                                                                                                     :sourceFormat ""
                                                                                                                                     :sourceUris []}
                                                                                                         :friendlyName ""
                                                                                                         :id ""
                                                                                                         :kind ""
                                                                                                         :labels {}
                                                                                                         :lastModifiedTime ""
                                                                                                         :location ""
                                                                                                         :materializedView {:allow_non_incremental_definition false
                                                                                                                            :enableRefresh false
                                                                                                                            :lastRefreshTime ""
                                                                                                                            :maxStaleness ""
                                                                                                                            :query ""
                                                                                                                            :refreshIntervalMs ""}
                                                                                                         :maxStaleness ""
                                                                                                         :model {:modelOptions {:labels []
                                                                                                                                :lossType ""
                                                                                                                                :modelType ""}
                                                                                                                 :trainingRuns [{:iterationResults [{:durationMs ""
                                                                                                                                                     :evalLoss ""
                                                                                                                                                     :index 0
                                                                                                                                                     :learnRate ""
                                                                                                                                                     :trainingLoss ""}]
                                                                                                                                 :startTime ""
                                                                                                                                 :state ""
                                                                                                                                 :trainingOptions {:earlyStop false
                                                                                                                                                   :l1Reg ""
                                                                                                                                                   :l2Reg ""
                                                                                                                                                   :learnRate ""
                                                                                                                                                   :learnRateStrategy ""
                                                                                                                                                   :lineSearchInitLearnRate ""
                                                                                                                                                   :maxIteration ""
                                                                                                                                                   :minRelProgress ""
                                                                                                                                                   :warmStart false}}]}
                                                                                                         :numBytes ""
                                                                                                         :numLongTermBytes ""
                                                                                                         :numPhysicalBytes ""
                                                                                                         :numRows ""
                                                                                                         :num_active_logical_bytes ""
                                                                                                         :num_active_physical_bytes ""
                                                                                                         :num_long_term_logical_bytes ""
                                                                                                         :num_long_term_physical_bytes ""
                                                                                                         :num_partitions ""
                                                                                                         :num_time_travel_physical_bytes ""
                                                                                                         :num_total_logical_bytes ""
                                                                                                         :num_total_physical_bytes ""
                                                                                                         :rangePartitioning {:field ""
                                                                                                                             :range {:end ""
                                                                                                                                     :interval ""
                                                                                                                                     :start ""}}
                                                                                                         :requirePartitionFilter false
                                                                                                         :schema {}
                                                                                                         :selfLink ""
                                                                                                         :snapshotDefinition {:baseTableReference {}
                                                                                                                              :snapshotTime ""}
                                                                                                         :streamingBuffer {:estimatedBytes ""
                                                                                                                           :estimatedRows ""
                                                                                                                           :oldestEntryTime ""}
                                                                                                         :tableReference {}
                                                                                                         :timePartitioning {:expirationMs ""
                                                                                                                            :field ""
                                                                                                                            :requirePartitionFilter false
                                                                                                                            :type ""}
                                                                                                         :type ""
                                                                                                         :view {:query ""
                                                                                                                :useExplicitColumnNames false
                                                                                                                :useLegacySql false
                                                                                                                :userDefinedFunctionResources [{:inlineCode ""
                                                                                                                                                :resourceUri ""}]}}})
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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}}/projects/:projectId/datasets/:datasetId/tables"),
    Content = new StringContent("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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}}/projects/:projectId/datasets/:datasetId/tables");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables"

	payload := strings.NewReader("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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/projects/:projectId/datasets/:datasetId/tables HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 4536

{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables")
  .header("content-type", "application/json")
  .body("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  cloneDefinition: {
    baseTableReference: {
      datasetId: '',
      projectId: '',
      tableId: ''
    },
    cloneTime: ''
  },
  clustering: {
    fields: []
  },
  creationTime: '',
  defaultCollation: '',
  defaultRoundingMode: '',
  description: '',
  encryptionConfiguration: {
    kmsKeyName: ''
  },
  etag: '',
  expirationTime: '',
  externalDataConfiguration: {
    autodetect: false,
    avroOptions: {
      useAvroLogicalTypes: false
    },
    bigtableOptions: {
      columnFamilies: [
        {
          columns: [
            {
              encoding: '',
              fieldName: '',
              onlyReadLatest: false,
              qualifierEncoded: '',
              qualifierString: '',
              type: ''
            }
          ],
          encoding: '',
          familyId: '',
          onlyReadLatest: false,
          type: ''
        }
      ],
      ignoreUnspecifiedColumnFamilies: false,
      readRowkeyAsString: false
    },
    compression: '',
    connectionId: '',
    csvOptions: {
      allowJaggedRows: false,
      allowQuotedNewlines: false,
      encoding: '',
      fieldDelimiter: '',
      null_marker: '',
      preserveAsciiControlCharacters: false,
      quote: '',
      skipLeadingRows: ''
    },
    decimalTargetTypes: [],
    googleSheetsOptions: {
      range: '',
      skipLeadingRows: ''
    },
    hivePartitioningOptions: {
      mode: '',
      requirePartitionFilter: false,
      sourceUriPrefix: ''
    },
    ignoreUnknownValues: false,
    maxBadRecords: 0,
    metadataCacheMode: '',
    objectMetadata: '',
    parquetOptions: {
      enableListInference: false,
      enumAsString: false
    },
    referenceFileSchemaUri: '',
    schema: {
      fields: [
        {
          categories: {
            names: []
          },
          collation: '',
          defaultValueExpression: '',
          description: '',
          fields: [],
          maxLength: '',
          mode: '',
          name: '',
          policyTags: {
            names: []
          },
          precision: '',
          roundingMode: '',
          scale: '',
          type: ''
        }
      ]
    },
    sourceFormat: '',
    sourceUris: []
  },
  friendlyName: '',
  id: '',
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  materializedView: {
    allow_non_incremental_definition: false,
    enableRefresh: false,
    lastRefreshTime: '',
    maxStaleness: '',
    query: '',
    refreshIntervalMs: ''
  },
  maxStaleness: '',
  model: {
    modelOptions: {
      labels: [],
      lossType: '',
      modelType: ''
    },
    trainingRuns: [
      {
        iterationResults: [
          {
            durationMs: '',
            evalLoss: '',
            index: 0,
            learnRate: '',
            trainingLoss: ''
          }
        ],
        startTime: '',
        state: '',
        trainingOptions: {
          earlyStop: false,
          l1Reg: '',
          l2Reg: '',
          learnRate: '',
          learnRateStrategy: '',
          lineSearchInitLearnRate: '',
          maxIteration: '',
          minRelProgress: '',
          warmStart: false
        }
      }
    ]
  },
  numBytes: '',
  numLongTermBytes: '',
  numPhysicalBytes: '',
  numRows: '',
  num_active_logical_bytes: '',
  num_active_physical_bytes: '',
  num_long_term_logical_bytes: '',
  num_long_term_physical_bytes: '',
  num_partitions: '',
  num_time_travel_physical_bytes: '',
  num_total_logical_bytes: '',
  num_total_physical_bytes: '',
  rangePartitioning: {
    field: '',
    range: {
      end: '',
      interval: '',
      start: ''
    }
  },
  requirePartitionFilter: false,
  schema: {},
  selfLink: '',
  snapshotDefinition: {
    baseTableReference: {},
    snapshotTime: ''
  },
  streamingBuffer: {
    estimatedBytes: '',
    estimatedRows: '',
    oldestEntryTime: ''
  },
  tableReference: {},
  timePartitioning: {
    expirationMs: '',
    field: '',
    requirePartitionFilter: false,
    type: ''
  },
  type: '',
  view: {
    query: '',
    useExplicitColumnNames: false,
    useLegacySql: false,
    userDefinedFunctionResources: [
      {
        inlineCode: '',
        resourceUri: ''
      }
    ]
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables',
  headers: {'content-type': 'application/json'},
  data: {
    cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
    clustering: {fields: []},
    creationTime: '',
    defaultCollation: '',
    defaultRoundingMode: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    externalDataConfiguration: {
      autodetect: false,
      avroOptions: {useAvroLogicalTypes: false},
      bigtableOptions: {
        columnFamilies: [
          {
            columns: [
              {
                encoding: '',
                fieldName: '',
                onlyReadLatest: false,
                qualifierEncoded: '',
                qualifierString: '',
                type: ''
              }
            ],
            encoding: '',
            familyId: '',
            onlyReadLatest: false,
            type: ''
          }
        ],
        ignoreUnspecifiedColumnFamilies: false,
        readRowkeyAsString: false
      },
      compression: '',
      connectionId: '',
      csvOptions: {
        allowJaggedRows: false,
        allowQuotedNewlines: false,
        encoding: '',
        fieldDelimiter: '',
        null_marker: '',
        preserveAsciiControlCharacters: false,
        quote: '',
        skipLeadingRows: ''
      },
      decimalTargetTypes: [],
      googleSheetsOptions: {range: '', skipLeadingRows: ''},
      hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
      ignoreUnknownValues: false,
      maxBadRecords: 0,
      metadataCacheMode: '',
      objectMetadata: '',
      parquetOptions: {enableListInference: false, enumAsString: false},
      referenceFileSchemaUri: '',
      schema: {
        fields: [
          {
            categories: {names: []},
            collation: '',
            defaultValueExpression: '',
            description: '',
            fields: [],
            maxLength: '',
            mode: '',
            name: '',
            policyTags: {names: []},
            precision: '',
            roundingMode: '',
            scale: '',
            type: ''
          }
        ]
      },
      sourceFormat: '',
      sourceUris: []
    },
    friendlyName: '',
    id: '',
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    materializedView: {
      allow_non_incremental_definition: false,
      enableRefresh: false,
      lastRefreshTime: '',
      maxStaleness: '',
      query: '',
      refreshIntervalMs: ''
    },
    maxStaleness: '',
    model: {
      modelOptions: {labels: [], lossType: '', modelType: ''},
      trainingRuns: [
        {
          iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
          startTime: '',
          state: '',
          trainingOptions: {
            earlyStop: false,
            l1Reg: '',
            l2Reg: '',
            learnRate: '',
            learnRateStrategy: '',
            lineSearchInitLearnRate: '',
            maxIteration: '',
            minRelProgress: '',
            warmStart: false
          }
        }
      ]
    },
    numBytes: '',
    numLongTermBytes: '',
    numPhysicalBytes: '',
    numRows: '',
    num_active_logical_bytes: '',
    num_active_physical_bytes: '',
    num_long_term_logical_bytes: '',
    num_long_term_physical_bytes: '',
    num_partitions: '',
    num_time_travel_physical_bytes: '',
    num_total_logical_bytes: '',
    num_total_physical_bytes: '',
    rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
    requirePartitionFilter: false,
    schema: {},
    selfLink: '',
    snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
    streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
    tableReference: {},
    timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
    type: '',
    view: {
      query: '',
      useExplicitColumnNames: false,
      useLegacySql: false,
      userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cloneDefinition":{"baseTableReference":{"datasetId":"","projectId":"","tableId":""},"cloneTime":""},"clustering":{"fields":[]},"creationTime":"","defaultCollation":"","defaultRoundingMode":"","description":"","encryptionConfiguration":{"kmsKeyName":""},"etag":"","expirationTime":"","externalDataConfiguration":{"autodetect":false,"avroOptions":{"useAvroLogicalTypes":false},"bigtableOptions":{"columnFamilies":[{"columns":[{"encoding":"","fieldName":"","onlyReadLatest":false,"qualifierEncoded":"","qualifierString":"","type":""}],"encoding":"","familyId":"","onlyReadLatest":false,"type":""}],"ignoreUnspecifiedColumnFamilies":false,"readRowkeyAsString":false},"compression":"","connectionId":"","csvOptions":{"allowJaggedRows":false,"allowQuotedNewlines":false,"encoding":"","fieldDelimiter":"","null_marker":"","preserveAsciiControlCharacters":false,"quote":"","skipLeadingRows":""},"decimalTargetTypes":[],"googleSheetsOptions":{"range":"","skipLeadingRows":""},"hivePartitioningOptions":{"mode":"","requirePartitionFilter":false,"sourceUriPrefix":""},"ignoreUnknownValues":false,"maxBadRecords":0,"metadataCacheMode":"","objectMetadata":"","parquetOptions":{"enableListInference":false,"enumAsString":false},"referenceFileSchemaUri":"","schema":{"fields":[{"categories":{"names":[]},"collation":"","defaultValueExpression":"","description":"","fields":[],"maxLength":"","mode":"","name":"","policyTags":{"names":[]},"precision":"","roundingMode":"","scale":"","type":""}]},"sourceFormat":"","sourceUris":[]},"friendlyName":"","id":"","kind":"","labels":{},"lastModifiedTime":"","location":"","materializedView":{"allow_non_incremental_definition":false,"enableRefresh":false,"lastRefreshTime":"","maxStaleness":"","query":"","refreshIntervalMs":""},"maxStaleness":"","model":{"modelOptions":{"labels":[],"lossType":"","modelType":""},"trainingRuns":[{"iterationResults":[{"durationMs":"","evalLoss":"","index":0,"learnRate":"","trainingLoss":""}],"startTime":"","state":"","trainingOptions":{"earlyStop":false,"l1Reg":"","l2Reg":"","learnRate":"","learnRateStrategy":"","lineSearchInitLearnRate":"","maxIteration":"","minRelProgress":"","warmStart":false}}]},"numBytes":"","numLongTermBytes":"","numPhysicalBytes":"","numRows":"","num_active_logical_bytes":"","num_active_physical_bytes":"","num_long_term_logical_bytes":"","num_long_term_physical_bytes":"","num_partitions":"","num_time_travel_physical_bytes":"","num_total_logical_bytes":"","num_total_physical_bytes":"","rangePartitioning":{"field":"","range":{"end":"","interval":"","start":""}},"requirePartitionFilter":false,"schema":{},"selfLink":"","snapshotDefinition":{"baseTableReference":{},"snapshotTime":""},"streamingBuffer":{"estimatedBytes":"","estimatedRows":"","oldestEntryTime":""},"tableReference":{},"timePartitioning":{"expirationMs":"","field":"","requirePartitionFilter":false,"type":""},"type":"","view":{"query":"","useExplicitColumnNames":false,"useLegacySql":false,"userDefinedFunctionResources":[{"inlineCode":"","resourceUri":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cloneDefinition": {\n    "baseTableReference": {\n      "datasetId": "",\n      "projectId": "",\n      "tableId": ""\n    },\n    "cloneTime": ""\n  },\n  "clustering": {\n    "fields": []\n  },\n  "creationTime": "",\n  "defaultCollation": "",\n  "defaultRoundingMode": "",\n  "description": "",\n  "encryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "etag": "",\n  "expirationTime": "",\n  "externalDataConfiguration": {\n    "autodetect": false,\n    "avroOptions": {\n      "useAvroLogicalTypes": false\n    },\n    "bigtableOptions": {\n      "columnFamilies": [\n        {\n          "columns": [\n            {\n              "encoding": "",\n              "fieldName": "",\n              "onlyReadLatest": false,\n              "qualifierEncoded": "",\n              "qualifierString": "",\n              "type": ""\n            }\n          ],\n          "encoding": "",\n          "familyId": "",\n          "onlyReadLatest": false,\n          "type": ""\n        }\n      ],\n      "ignoreUnspecifiedColumnFamilies": false,\n      "readRowkeyAsString": false\n    },\n    "compression": "",\n    "connectionId": "",\n    "csvOptions": {\n      "allowJaggedRows": false,\n      "allowQuotedNewlines": false,\n      "encoding": "",\n      "fieldDelimiter": "",\n      "null_marker": "",\n      "preserveAsciiControlCharacters": false,\n      "quote": "",\n      "skipLeadingRows": ""\n    },\n    "decimalTargetTypes": [],\n    "googleSheetsOptions": {\n      "range": "",\n      "skipLeadingRows": ""\n    },\n    "hivePartitioningOptions": {\n      "mode": "",\n      "requirePartitionFilter": false,\n      "sourceUriPrefix": ""\n    },\n    "ignoreUnknownValues": false,\n    "maxBadRecords": 0,\n    "metadataCacheMode": "",\n    "objectMetadata": "",\n    "parquetOptions": {\n      "enableListInference": false,\n      "enumAsString": false\n    },\n    "referenceFileSchemaUri": "",\n    "schema": {\n      "fields": [\n        {\n          "categories": {\n            "names": []\n          },\n          "collation": "",\n          "defaultValueExpression": "",\n          "description": "",\n          "fields": [],\n          "maxLength": "",\n          "mode": "",\n          "name": "",\n          "policyTags": {\n            "names": []\n          },\n          "precision": "",\n          "roundingMode": "",\n          "scale": "",\n          "type": ""\n        }\n      ]\n    },\n    "sourceFormat": "",\n    "sourceUris": []\n  },\n  "friendlyName": "",\n  "id": "",\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "materializedView": {\n    "allow_non_incremental_definition": false,\n    "enableRefresh": false,\n    "lastRefreshTime": "",\n    "maxStaleness": "",\n    "query": "",\n    "refreshIntervalMs": ""\n  },\n  "maxStaleness": "",\n  "model": {\n    "modelOptions": {\n      "labels": [],\n      "lossType": "",\n      "modelType": ""\n    },\n    "trainingRuns": [\n      {\n        "iterationResults": [\n          {\n            "durationMs": "",\n            "evalLoss": "",\n            "index": 0,\n            "learnRate": "",\n            "trainingLoss": ""\n          }\n        ],\n        "startTime": "",\n        "state": "",\n        "trainingOptions": {\n          "earlyStop": false,\n          "l1Reg": "",\n          "l2Reg": "",\n          "learnRate": "",\n          "learnRateStrategy": "",\n          "lineSearchInitLearnRate": "",\n          "maxIteration": "",\n          "minRelProgress": "",\n          "warmStart": false\n        }\n      }\n    ]\n  },\n  "numBytes": "",\n  "numLongTermBytes": "",\n  "numPhysicalBytes": "",\n  "numRows": "",\n  "num_active_logical_bytes": "",\n  "num_active_physical_bytes": "",\n  "num_long_term_logical_bytes": "",\n  "num_long_term_physical_bytes": "",\n  "num_partitions": "",\n  "num_time_travel_physical_bytes": "",\n  "num_total_logical_bytes": "",\n  "num_total_physical_bytes": "",\n  "rangePartitioning": {\n    "field": "",\n    "range": {\n      "end": "",\n      "interval": "",\n      "start": ""\n    }\n  },\n  "requirePartitionFilter": false,\n  "schema": {},\n  "selfLink": "",\n  "snapshotDefinition": {\n    "baseTableReference": {},\n    "snapshotTime": ""\n  },\n  "streamingBuffer": {\n    "estimatedBytes": "",\n    "estimatedRows": "",\n    "oldestEntryTime": ""\n  },\n  "tableReference": {},\n  "timePartitioning": {\n    "expirationMs": "",\n    "field": "",\n    "requirePartitionFilter": false,\n    "type": ""\n  },\n  "type": "",\n  "view": {\n    "query": "",\n    "useExplicitColumnNames": false,\n    "useLegacySql": false,\n    "userDefinedFunctionResources": [\n      {\n        "inlineCode": "",\n        "resourceUri": ""\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  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables")
  .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/projects/:projectId/datasets/:datasetId/tables',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
  clustering: {fields: []},
  creationTime: '',
  defaultCollation: '',
  defaultRoundingMode: '',
  description: '',
  encryptionConfiguration: {kmsKeyName: ''},
  etag: '',
  expirationTime: '',
  externalDataConfiguration: {
    autodetect: false,
    avroOptions: {useAvroLogicalTypes: false},
    bigtableOptions: {
      columnFamilies: [
        {
          columns: [
            {
              encoding: '',
              fieldName: '',
              onlyReadLatest: false,
              qualifierEncoded: '',
              qualifierString: '',
              type: ''
            }
          ],
          encoding: '',
          familyId: '',
          onlyReadLatest: false,
          type: ''
        }
      ],
      ignoreUnspecifiedColumnFamilies: false,
      readRowkeyAsString: false
    },
    compression: '',
    connectionId: '',
    csvOptions: {
      allowJaggedRows: false,
      allowQuotedNewlines: false,
      encoding: '',
      fieldDelimiter: '',
      null_marker: '',
      preserveAsciiControlCharacters: false,
      quote: '',
      skipLeadingRows: ''
    },
    decimalTargetTypes: [],
    googleSheetsOptions: {range: '', skipLeadingRows: ''},
    hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
    ignoreUnknownValues: false,
    maxBadRecords: 0,
    metadataCacheMode: '',
    objectMetadata: '',
    parquetOptions: {enableListInference: false, enumAsString: false},
    referenceFileSchemaUri: '',
    schema: {
      fields: [
        {
          categories: {names: []},
          collation: '',
          defaultValueExpression: '',
          description: '',
          fields: [],
          maxLength: '',
          mode: '',
          name: '',
          policyTags: {names: []},
          precision: '',
          roundingMode: '',
          scale: '',
          type: ''
        }
      ]
    },
    sourceFormat: '',
    sourceUris: []
  },
  friendlyName: '',
  id: '',
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  materializedView: {
    allow_non_incremental_definition: false,
    enableRefresh: false,
    lastRefreshTime: '',
    maxStaleness: '',
    query: '',
    refreshIntervalMs: ''
  },
  maxStaleness: '',
  model: {
    modelOptions: {labels: [], lossType: '', modelType: ''},
    trainingRuns: [
      {
        iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
        startTime: '',
        state: '',
        trainingOptions: {
          earlyStop: false,
          l1Reg: '',
          l2Reg: '',
          learnRate: '',
          learnRateStrategy: '',
          lineSearchInitLearnRate: '',
          maxIteration: '',
          minRelProgress: '',
          warmStart: false
        }
      }
    ]
  },
  numBytes: '',
  numLongTermBytes: '',
  numPhysicalBytes: '',
  numRows: '',
  num_active_logical_bytes: '',
  num_active_physical_bytes: '',
  num_long_term_logical_bytes: '',
  num_long_term_physical_bytes: '',
  num_partitions: '',
  num_time_travel_physical_bytes: '',
  num_total_logical_bytes: '',
  num_total_physical_bytes: '',
  rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
  requirePartitionFilter: false,
  schema: {},
  selfLink: '',
  snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
  streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
  tableReference: {},
  timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
  type: '',
  view: {
    query: '',
    useExplicitColumnNames: false,
    useLegacySql: false,
    userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables',
  headers: {'content-type': 'application/json'},
  body: {
    cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
    clustering: {fields: []},
    creationTime: '',
    defaultCollation: '',
    defaultRoundingMode: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    externalDataConfiguration: {
      autodetect: false,
      avroOptions: {useAvroLogicalTypes: false},
      bigtableOptions: {
        columnFamilies: [
          {
            columns: [
              {
                encoding: '',
                fieldName: '',
                onlyReadLatest: false,
                qualifierEncoded: '',
                qualifierString: '',
                type: ''
              }
            ],
            encoding: '',
            familyId: '',
            onlyReadLatest: false,
            type: ''
          }
        ],
        ignoreUnspecifiedColumnFamilies: false,
        readRowkeyAsString: false
      },
      compression: '',
      connectionId: '',
      csvOptions: {
        allowJaggedRows: false,
        allowQuotedNewlines: false,
        encoding: '',
        fieldDelimiter: '',
        null_marker: '',
        preserveAsciiControlCharacters: false,
        quote: '',
        skipLeadingRows: ''
      },
      decimalTargetTypes: [],
      googleSheetsOptions: {range: '', skipLeadingRows: ''},
      hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
      ignoreUnknownValues: false,
      maxBadRecords: 0,
      metadataCacheMode: '',
      objectMetadata: '',
      parquetOptions: {enableListInference: false, enumAsString: false},
      referenceFileSchemaUri: '',
      schema: {
        fields: [
          {
            categories: {names: []},
            collation: '',
            defaultValueExpression: '',
            description: '',
            fields: [],
            maxLength: '',
            mode: '',
            name: '',
            policyTags: {names: []},
            precision: '',
            roundingMode: '',
            scale: '',
            type: ''
          }
        ]
      },
      sourceFormat: '',
      sourceUris: []
    },
    friendlyName: '',
    id: '',
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    materializedView: {
      allow_non_incremental_definition: false,
      enableRefresh: false,
      lastRefreshTime: '',
      maxStaleness: '',
      query: '',
      refreshIntervalMs: ''
    },
    maxStaleness: '',
    model: {
      modelOptions: {labels: [], lossType: '', modelType: ''},
      trainingRuns: [
        {
          iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
          startTime: '',
          state: '',
          trainingOptions: {
            earlyStop: false,
            l1Reg: '',
            l2Reg: '',
            learnRate: '',
            learnRateStrategy: '',
            lineSearchInitLearnRate: '',
            maxIteration: '',
            minRelProgress: '',
            warmStart: false
          }
        }
      ]
    },
    numBytes: '',
    numLongTermBytes: '',
    numPhysicalBytes: '',
    numRows: '',
    num_active_logical_bytes: '',
    num_active_physical_bytes: '',
    num_long_term_logical_bytes: '',
    num_long_term_physical_bytes: '',
    num_partitions: '',
    num_time_travel_physical_bytes: '',
    num_total_logical_bytes: '',
    num_total_physical_bytes: '',
    rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
    requirePartitionFilter: false,
    schema: {},
    selfLink: '',
    snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
    streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
    tableReference: {},
    timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
    type: '',
    view: {
      query: '',
      useExplicitColumnNames: false,
      useLegacySql: false,
      userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
    }
  },
  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}}/projects/:projectId/datasets/:datasetId/tables');

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

req.type('json');
req.send({
  cloneDefinition: {
    baseTableReference: {
      datasetId: '',
      projectId: '',
      tableId: ''
    },
    cloneTime: ''
  },
  clustering: {
    fields: []
  },
  creationTime: '',
  defaultCollation: '',
  defaultRoundingMode: '',
  description: '',
  encryptionConfiguration: {
    kmsKeyName: ''
  },
  etag: '',
  expirationTime: '',
  externalDataConfiguration: {
    autodetect: false,
    avroOptions: {
      useAvroLogicalTypes: false
    },
    bigtableOptions: {
      columnFamilies: [
        {
          columns: [
            {
              encoding: '',
              fieldName: '',
              onlyReadLatest: false,
              qualifierEncoded: '',
              qualifierString: '',
              type: ''
            }
          ],
          encoding: '',
          familyId: '',
          onlyReadLatest: false,
          type: ''
        }
      ],
      ignoreUnspecifiedColumnFamilies: false,
      readRowkeyAsString: false
    },
    compression: '',
    connectionId: '',
    csvOptions: {
      allowJaggedRows: false,
      allowQuotedNewlines: false,
      encoding: '',
      fieldDelimiter: '',
      null_marker: '',
      preserveAsciiControlCharacters: false,
      quote: '',
      skipLeadingRows: ''
    },
    decimalTargetTypes: [],
    googleSheetsOptions: {
      range: '',
      skipLeadingRows: ''
    },
    hivePartitioningOptions: {
      mode: '',
      requirePartitionFilter: false,
      sourceUriPrefix: ''
    },
    ignoreUnknownValues: false,
    maxBadRecords: 0,
    metadataCacheMode: '',
    objectMetadata: '',
    parquetOptions: {
      enableListInference: false,
      enumAsString: false
    },
    referenceFileSchemaUri: '',
    schema: {
      fields: [
        {
          categories: {
            names: []
          },
          collation: '',
          defaultValueExpression: '',
          description: '',
          fields: [],
          maxLength: '',
          mode: '',
          name: '',
          policyTags: {
            names: []
          },
          precision: '',
          roundingMode: '',
          scale: '',
          type: ''
        }
      ]
    },
    sourceFormat: '',
    sourceUris: []
  },
  friendlyName: '',
  id: '',
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  materializedView: {
    allow_non_incremental_definition: false,
    enableRefresh: false,
    lastRefreshTime: '',
    maxStaleness: '',
    query: '',
    refreshIntervalMs: ''
  },
  maxStaleness: '',
  model: {
    modelOptions: {
      labels: [],
      lossType: '',
      modelType: ''
    },
    trainingRuns: [
      {
        iterationResults: [
          {
            durationMs: '',
            evalLoss: '',
            index: 0,
            learnRate: '',
            trainingLoss: ''
          }
        ],
        startTime: '',
        state: '',
        trainingOptions: {
          earlyStop: false,
          l1Reg: '',
          l2Reg: '',
          learnRate: '',
          learnRateStrategy: '',
          lineSearchInitLearnRate: '',
          maxIteration: '',
          minRelProgress: '',
          warmStart: false
        }
      }
    ]
  },
  numBytes: '',
  numLongTermBytes: '',
  numPhysicalBytes: '',
  numRows: '',
  num_active_logical_bytes: '',
  num_active_physical_bytes: '',
  num_long_term_logical_bytes: '',
  num_long_term_physical_bytes: '',
  num_partitions: '',
  num_time_travel_physical_bytes: '',
  num_total_logical_bytes: '',
  num_total_physical_bytes: '',
  rangePartitioning: {
    field: '',
    range: {
      end: '',
      interval: '',
      start: ''
    }
  },
  requirePartitionFilter: false,
  schema: {},
  selfLink: '',
  snapshotDefinition: {
    baseTableReference: {},
    snapshotTime: ''
  },
  streamingBuffer: {
    estimatedBytes: '',
    estimatedRows: '',
    oldestEntryTime: ''
  },
  tableReference: {},
  timePartitioning: {
    expirationMs: '',
    field: '',
    requirePartitionFilter: false,
    type: ''
  },
  type: '',
  view: {
    query: '',
    useExplicitColumnNames: false,
    useLegacySql: false,
    userDefinedFunctionResources: [
      {
        inlineCode: '',
        resourceUri: ''
      }
    ]
  }
});

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}}/projects/:projectId/datasets/:datasetId/tables',
  headers: {'content-type': 'application/json'},
  data: {
    cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
    clustering: {fields: []},
    creationTime: '',
    defaultCollation: '',
    defaultRoundingMode: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    externalDataConfiguration: {
      autodetect: false,
      avroOptions: {useAvroLogicalTypes: false},
      bigtableOptions: {
        columnFamilies: [
          {
            columns: [
              {
                encoding: '',
                fieldName: '',
                onlyReadLatest: false,
                qualifierEncoded: '',
                qualifierString: '',
                type: ''
              }
            ],
            encoding: '',
            familyId: '',
            onlyReadLatest: false,
            type: ''
          }
        ],
        ignoreUnspecifiedColumnFamilies: false,
        readRowkeyAsString: false
      },
      compression: '',
      connectionId: '',
      csvOptions: {
        allowJaggedRows: false,
        allowQuotedNewlines: false,
        encoding: '',
        fieldDelimiter: '',
        null_marker: '',
        preserveAsciiControlCharacters: false,
        quote: '',
        skipLeadingRows: ''
      },
      decimalTargetTypes: [],
      googleSheetsOptions: {range: '', skipLeadingRows: ''},
      hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
      ignoreUnknownValues: false,
      maxBadRecords: 0,
      metadataCacheMode: '',
      objectMetadata: '',
      parquetOptions: {enableListInference: false, enumAsString: false},
      referenceFileSchemaUri: '',
      schema: {
        fields: [
          {
            categories: {names: []},
            collation: '',
            defaultValueExpression: '',
            description: '',
            fields: [],
            maxLength: '',
            mode: '',
            name: '',
            policyTags: {names: []},
            precision: '',
            roundingMode: '',
            scale: '',
            type: ''
          }
        ]
      },
      sourceFormat: '',
      sourceUris: []
    },
    friendlyName: '',
    id: '',
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    materializedView: {
      allow_non_incremental_definition: false,
      enableRefresh: false,
      lastRefreshTime: '',
      maxStaleness: '',
      query: '',
      refreshIntervalMs: ''
    },
    maxStaleness: '',
    model: {
      modelOptions: {labels: [], lossType: '', modelType: ''},
      trainingRuns: [
        {
          iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
          startTime: '',
          state: '',
          trainingOptions: {
            earlyStop: false,
            l1Reg: '',
            l2Reg: '',
            learnRate: '',
            learnRateStrategy: '',
            lineSearchInitLearnRate: '',
            maxIteration: '',
            minRelProgress: '',
            warmStart: false
          }
        }
      ]
    },
    numBytes: '',
    numLongTermBytes: '',
    numPhysicalBytes: '',
    numRows: '',
    num_active_logical_bytes: '',
    num_active_physical_bytes: '',
    num_long_term_logical_bytes: '',
    num_long_term_physical_bytes: '',
    num_partitions: '',
    num_time_travel_physical_bytes: '',
    num_total_logical_bytes: '',
    num_total_physical_bytes: '',
    rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
    requirePartitionFilter: false,
    schema: {},
    selfLink: '',
    snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
    streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
    tableReference: {},
    timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
    type: '',
    view: {
      query: '',
      useExplicitColumnNames: false,
      useLegacySql: false,
      userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
    }
  }
};

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

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cloneDefinition":{"baseTableReference":{"datasetId":"","projectId":"","tableId":""},"cloneTime":""},"clustering":{"fields":[]},"creationTime":"","defaultCollation":"","defaultRoundingMode":"","description":"","encryptionConfiguration":{"kmsKeyName":""},"etag":"","expirationTime":"","externalDataConfiguration":{"autodetect":false,"avroOptions":{"useAvroLogicalTypes":false},"bigtableOptions":{"columnFamilies":[{"columns":[{"encoding":"","fieldName":"","onlyReadLatest":false,"qualifierEncoded":"","qualifierString":"","type":""}],"encoding":"","familyId":"","onlyReadLatest":false,"type":""}],"ignoreUnspecifiedColumnFamilies":false,"readRowkeyAsString":false},"compression":"","connectionId":"","csvOptions":{"allowJaggedRows":false,"allowQuotedNewlines":false,"encoding":"","fieldDelimiter":"","null_marker":"","preserveAsciiControlCharacters":false,"quote":"","skipLeadingRows":""},"decimalTargetTypes":[],"googleSheetsOptions":{"range":"","skipLeadingRows":""},"hivePartitioningOptions":{"mode":"","requirePartitionFilter":false,"sourceUriPrefix":""},"ignoreUnknownValues":false,"maxBadRecords":0,"metadataCacheMode":"","objectMetadata":"","parquetOptions":{"enableListInference":false,"enumAsString":false},"referenceFileSchemaUri":"","schema":{"fields":[{"categories":{"names":[]},"collation":"","defaultValueExpression":"","description":"","fields":[],"maxLength":"","mode":"","name":"","policyTags":{"names":[]},"precision":"","roundingMode":"","scale":"","type":""}]},"sourceFormat":"","sourceUris":[]},"friendlyName":"","id":"","kind":"","labels":{},"lastModifiedTime":"","location":"","materializedView":{"allow_non_incremental_definition":false,"enableRefresh":false,"lastRefreshTime":"","maxStaleness":"","query":"","refreshIntervalMs":""},"maxStaleness":"","model":{"modelOptions":{"labels":[],"lossType":"","modelType":""},"trainingRuns":[{"iterationResults":[{"durationMs":"","evalLoss":"","index":0,"learnRate":"","trainingLoss":""}],"startTime":"","state":"","trainingOptions":{"earlyStop":false,"l1Reg":"","l2Reg":"","learnRate":"","learnRateStrategy":"","lineSearchInitLearnRate":"","maxIteration":"","minRelProgress":"","warmStart":false}}]},"numBytes":"","numLongTermBytes":"","numPhysicalBytes":"","numRows":"","num_active_logical_bytes":"","num_active_physical_bytes":"","num_long_term_logical_bytes":"","num_long_term_physical_bytes":"","num_partitions":"","num_time_travel_physical_bytes":"","num_total_logical_bytes":"","num_total_physical_bytes":"","rangePartitioning":{"field":"","range":{"end":"","interval":"","start":""}},"requirePartitionFilter":false,"schema":{},"selfLink":"","snapshotDefinition":{"baseTableReference":{},"snapshotTime":""},"streamingBuffer":{"estimatedBytes":"","estimatedRows":"","oldestEntryTime":""},"tableReference":{},"timePartitioning":{"expirationMs":"","field":"","requirePartitionFilter":false,"type":""},"type":"","view":{"query":"","useExplicitColumnNames":false,"useLegacySql":false,"userDefinedFunctionResources":[{"inlineCode":"","resourceUri":""}]}}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"cloneDefinition": @{ @"baseTableReference": @{ @"datasetId": @"", @"projectId": @"", @"tableId": @"" }, @"cloneTime": @"" },
                              @"clustering": @{ @"fields": @[  ] },
                              @"creationTime": @"",
                              @"defaultCollation": @"",
                              @"defaultRoundingMode": @"",
                              @"description": @"",
                              @"encryptionConfiguration": @{ @"kmsKeyName": @"" },
                              @"etag": @"",
                              @"expirationTime": @"",
                              @"externalDataConfiguration": @{ @"autodetect": @NO, @"avroOptions": @{ @"useAvroLogicalTypes": @NO }, @"bigtableOptions": @{ @"columnFamilies": @[ @{ @"columns": @[ @{ @"encoding": @"", @"fieldName": @"", @"onlyReadLatest": @NO, @"qualifierEncoded": @"", @"qualifierString": @"", @"type": @"" } ], @"encoding": @"", @"familyId": @"", @"onlyReadLatest": @NO, @"type": @"" } ], @"ignoreUnspecifiedColumnFamilies": @NO, @"readRowkeyAsString": @NO }, @"compression": @"", @"connectionId": @"", @"csvOptions": @{ @"allowJaggedRows": @NO, @"allowQuotedNewlines": @NO, @"encoding": @"", @"fieldDelimiter": @"", @"null_marker": @"", @"preserveAsciiControlCharacters": @NO, @"quote": @"", @"skipLeadingRows": @"" }, @"decimalTargetTypes": @[  ], @"googleSheetsOptions": @{ @"range": @"", @"skipLeadingRows": @"" }, @"hivePartitioningOptions": @{ @"mode": @"", @"requirePartitionFilter": @NO, @"sourceUriPrefix": @"" }, @"ignoreUnknownValues": @NO, @"maxBadRecords": @0, @"metadataCacheMode": @"", @"objectMetadata": @"", @"parquetOptions": @{ @"enableListInference": @NO, @"enumAsString": @NO }, @"referenceFileSchemaUri": @"", @"schema": @{ @"fields": @[ @{ @"categories": @{ @"names": @[  ] }, @"collation": @"", @"defaultValueExpression": @"", @"description": @"", @"fields": @[  ], @"maxLength": @"", @"mode": @"", @"name": @"", @"policyTags": @{ @"names": @[  ] }, @"precision": @"", @"roundingMode": @"", @"scale": @"", @"type": @"" } ] }, @"sourceFormat": @"", @"sourceUris": @[  ] },
                              @"friendlyName": @"",
                              @"id": @"",
                              @"kind": @"",
                              @"labels": @{  },
                              @"lastModifiedTime": @"",
                              @"location": @"",
                              @"materializedView": @{ @"allow_non_incremental_definition": @NO, @"enableRefresh": @NO, @"lastRefreshTime": @"", @"maxStaleness": @"", @"query": @"", @"refreshIntervalMs": @"" },
                              @"maxStaleness": @"",
                              @"model": @{ @"modelOptions": @{ @"labels": @[  ], @"lossType": @"", @"modelType": @"" }, @"trainingRuns": @[ @{ @"iterationResults": @[ @{ @"durationMs": @"", @"evalLoss": @"", @"index": @0, @"learnRate": @"", @"trainingLoss": @"" } ], @"startTime": @"", @"state": @"", @"trainingOptions": @{ @"earlyStop": @NO, @"l1Reg": @"", @"l2Reg": @"", @"learnRate": @"", @"learnRateStrategy": @"", @"lineSearchInitLearnRate": @"", @"maxIteration": @"", @"minRelProgress": @"", @"warmStart": @NO } } ] },
                              @"numBytes": @"",
                              @"numLongTermBytes": @"",
                              @"numPhysicalBytes": @"",
                              @"numRows": @"",
                              @"num_active_logical_bytes": @"",
                              @"num_active_physical_bytes": @"",
                              @"num_long_term_logical_bytes": @"",
                              @"num_long_term_physical_bytes": @"",
                              @"num_partitions": @"",
                              @"num_time_travel_physical_bytes": @"",
                              @"num_total_logical_bytes": @"",
                              @"num_total_physical_bytes": @"",
                              @"rangePartitioning": @{ @"field": @"", @"range": @{ @"end": @"", @"interval": @"", @"start": @"" } },
                              @"requirePartitionFilter": @NO,
                              @"schema": @{  },
                              @"selfLink": @"",
                              @"snapshotDefinition": @{ @"baseTableReference": @{  }, @"snapshotTime": @"" },
                              @"streamingBuffer": @{ @"estimatedBytes": @"", @"estimatedRows": @"", @"oldestEntryTime": @"" },
                              @"tableReference": @{  },
                              @"timePartitioning": @{ @"expirationMs": @"", @"field": @"", @"requirePartitionFilter": @NO, @"type": @"" },
                              @"type": @"",
                              @"view": @{ @"query": @"", @"useExplicitColumnNames": @NO, @"useLegacySql": @NO, @"userDefinedFunctionResources": @[ @{ @"inlineCode": @"", @"resourceUri": @"" } ] } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables"]
                                                       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}}/projects/:projectId/datasets/:datasetId/tables" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables",
  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([
    'cloneDefinition' => [
        'baseTableReference' => [
                'datasetId' => '',
                'projectId' => '',
                'tableId' => ''
        ],
        'cloneTime' => ''
    ],
    'clustering' => [
        'fields' => [
                
        ]
    ],
    'creationTime' => '',
    'defaultCollation' => '',
    'defaultRoundingMode' => '',
    'description' => '',
    'encryptionConfiguration' => [
        'kmsKeyName' => ''
    ],
    'etag' => '',
    'expirationTime' => '',
    'externalDataConfiguration' => [
        'autodetect' => null,
        'avroOptions' => [
                'useAvroLogicalTypes' => null
        ],
        'bigtableOptions' => [
                'columnFamilies' => [
                                [
                                                                'columns' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'encoding' => '',
                                                                                                                                                                                                                                                                'fieldName' => '',
                                                                                                                                                                                                                                                                'onlyReadLatest' => null,
                                                                                                                                                                                                                                                                'qualifierEncoded' => '',
                                                                                                                                                                                                                                                                'qualifierString' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'encoding' => '',
                                                                'familyId' => '',
                                                                'onlyReadLatest' => null,
                                                                'type' => ''
                                ]
                ],
                'ignoreUnspecifiedColumnFamilies' => null,
                'readRowkeyAsString' => null
        ],
        'compression' => '',
        'connectionId' => '',
        'csvOptions' => [
                'allowJaggedRows' => null,
                'allowQuotedNewlines' => null,
                'encoding' => '',
                'fieldDelimiter' => '',
                'null_marker' => '',
                'preserveAsciiControlCharacters' => null,
                'quote' => '',
                'skipLeadingRows' => ''
        ],
        'decimalTargetTypes' => [
                
        ],
        'googleSheetsOptions' => [
                'range' => '',
                'skipLeadingRows' => ''
        ],
        'hivePartitioningOptions' => [
                'mode' => '',
                'requirePartitionFilter' => null,
                'sourceUriPrefix' => ''
        ],
        'ignoreUnknownValues' => null,
        'maxBadRecords' => 0,
        'metadataCacheMode' => '',
        'objectMetadata' => '',
        'parquetOptions' => [
                'enableListInference' => null,
                'enumAsString' => null
        ],
        'referenceFileSchemaUri' => '',
        'schema' => [
                'fields' => [
                                [
                                                                'categories' => [
                                                                                                                                'names' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'collation' => '',
                                                                'defaultValueExpression' => '',
                                                                'description' => '',
                                                                'fields' => [
                                                                                                                                
                                                                ],
                                                                'maxLength' => '',
                                                                'mode' => '',
                                                                'name' => '',
                                                                'policyTags' => [
                                                                                                                                'names' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'precision' => '',
                                                                'roundingMode' => '',
                                                                'scale' => '',
                                                                'type' => ''
                                ]
                ]
        ],
        'sourceFormat' => '',
        'sourceUris' => [
                
        ]
    ],
    'friendlyName' => '',
    'id' => '',
    'kind' => '',
    'labels' => [
        
    ],
    'lastModifiedTime' => '',
    'location' => '',
    'materializedView' => [
        'allow_non_incremental_definition' => null,
        'enableRefresh' => null,
        'lastRefreshTime' => '',
        'maxStaleness' => '',
        'query' => '',
        'refreshIntervalMs' => ''
    ],
    'maxStaleness' => '',
    'model' => [
        'modelOptions' => [
                'labels' => [
                                
                ],
                'lossType' => '',
                'modelType' => ''
        ],
        'trainingRuns' => [
                [
                                'iterationResults' => [
                                                                [
                                                                                                                                'durationMs' => '',
                                                                                                                                'evalLoss' => '',
                                                                                                                                'index' => 0,
                                                                                                                                'learnRate' => '',
                                                                                                                                'trainingLoss' => ''
                                                                ]
                                ],
                                'startTime' => '',
                                'state' => '',
                                'trainingOptions' => [
                                                                'earlyStop' => null,
                                                                'l1Reg' => '',
                                                                'l2Reg' => '',
                                                                'learnRate' => '',
                                                                'learnRateStrategy' => '',
                                                                'lineSearchInitLearnRate' => '',
                                                                'maxIteration' => '',
                                                                'minRelProgress' => '',
                                                                'warmStart' => null
                                ]
                ]
        ]
    ],
    'numBytes' => '',
    'numLongTermBytes' => '',
    'numPhysicalBytes' => '',
    'numRows' => '',
    'num_active_logical_bytes' => '',
    'num_active_physical_bytes' => '',
    'num_long_term_logical_bytes' => '',
    'num_long_term_physical_bytes' => '',
    'num_partitions' => '',
    'num_time_travel_physical_bytes' => '',
    'num_total_logical_bytes' => '',
    'num_total_physical_bytes' => '',
    'rangePartitioning' => [
        'field' => '',
        'range' => [
                'end' => '',
                'interval' => '',
                'start' => ''
        ]
    ],
    'requirePartitionFilter' => null,
    'schema' => [
        
    ],
    'selfLink' => '',
    'snapshotDefinition' => [
        'baseTableReference' => [
                
        ],
        'snapshotTime' => ''
    ],
    'streamingBuffer' => [
        'estimatedBytes' => '',
        'estimatedRows' => '',
        'oldestEntryTime' => ''
    ],
    'tableReference' => [
        
    ],
    'timePartitioning' => [
        'expirationMs' => '',
        'field' => '',
        'requirePartitionFilter' => null,
        'type' => ''
    ],
    'type' => '',
    'view' => [
        'query' => '',
        'useExplicitColumnNames' => null,
        'useLegacySql' => null,
        'userDefinedFunctionResources' => [
                [
                                'inlineCode' => '',
                                'resourceUri' => ''
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-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}}/projects/:projectId/datasets/:datasetId/tables', [
  'body' => '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cloneDefinition' => [
    'baseTableReference' => [
        'datasetId' => '',
        'projectId' => '',
        'tableId' => ''
    ],
    'cloneTime' => ''
  ],
  'clustering' => [
    'fields' => [
        
    ]
  ],
  'creationTime' => '',
  'defaultCollation' => '',
  'defaultRoundingMode' => '',
  'description' => '',
  'encryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'etag' => '',
  'expirationTime' => '',
  'externalDataConfiguration' => [
    'autodetect' => null,
    'avroOptions' => [
        'useAvroLogicalTypes' => null
    ],
    'bigtableOptions' => [
        'columnFamilies' => [
                [
                                'columns' => [
                                                                [
                                                                                                                                'encoding' => '',
                                                                                                                                'fieldName' => '',
                                                                                                                                'onlyReadLatest' => null,
                                                                                                                                'qualifierEncoded' => '',
                                                                                                                                'qualifierString' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'encoding' => '',
                                'familyId' => '',
                                'onlyReadLatest' => null,
                                'type' => ''
                ]
        ],
        'ignoreUnspecifiedColumnFamilies' => null,
        'readRowkeyAsString' => null
    ],
    'compression' => '',
    'connectionId' => '',
    'csvOptions' => [
        'allowJaggedRows' => null,
        'allowQuotedNewlines' => null,
        'encoding' => '',
        'fieldDelimiter' => '',
        'null_marker' => '',
        'preserveAsciiControlCharacters' => null,
        'quote' => '',
        'skipLeadingRows' => ''
    ],
    'decimalTargetTypes' => [
        
    ],
    'googleSheetsOptions' => [
        'range' => '',
        'skipLeadingRows' => ''
    ],
    'hivePartitioningOptions' => [
        'mode' => '',
        'requirePartitionFilter' => null,
        'sourceUriPrefix' => ''
    ],
    'ignoreUnknownValues' => null,
    'maxBadRecords' => 0,
    'metadataCacheMode' => '',
    'objectMetadata' => '',
    'parquetOptions' => [
        'enableListInference' => null,
        'enumAsString' => null
    ],
    'referenceFileSchemaUri' => '',
    'schema' => [
        'fields' => [
                [
                                'categories' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'collation' => '',
                                'defaultValueExpression' => '',
                                'description' => '',
                                'fields' => [
                                                                
                                ],
                                'maxLength' => '',
                                'mode' => '',
                                'name' => '',
                                'policyTags' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'precision' => '',
                                'roundingMode' => '',
                                'scale' => '',
                                'type' => ''
                ]
        ]
    ],
    'sourceFormat' => '',
    'sourceUris' => [
        
    ]
  ],
  'friendlyName' => '',
  'id' => '',
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'materializedView' => [
    'allow_non_incremental_definition' => null,
    'enableRefresh' => null,
    'lastRefreshTime' => '',
    'maxStaleness' => '',
    'query' => '',
    'refreshIntervalMs' => ''
  ],
  'maxStaleness' => '',
  'model' => [
    'modelOptions' => [
        'labels' => [
                
        ],
        'lossType' => '',
        'modelType' => ''
    ],
    'trainingRuns' => [
        [
                'iterationResults' => [
                                [
                                                                'durationMs' => '',
                                                                'evalLoss' => '',
                                                                'index' => 0,
                                                                'learnRate' => '',
                                                                'trainingLoss' => ''
                                ]
                ],
                'startTime' => '',
                'state' => '',
                'trainingOptions' => [
                                'earlyStop' => null,
                                'l1Reg' => '',
                                'l2Reg' => '',
                                'learnRate' => '',
                                'learnRateStrategy' => '',
                                'lineSearchInitLearnRate' => '',
                                'maxIteration' => '',
                                'minRelProgress' => '',
                                'warmStart' => null
                ]
        ]
    ]
  ],
  'numBytes' => '',
  'numLongTermBytes' => '',
  'numPhysicalBytes' => '',
  'numRows' => '',
  'num_active_logical_bytes' => '',
  'num_active_physical_bytes' => '',
  'num_long_term_logical_bytes' => '',
  'num_long_term_physical_bytes' => '',
  'num_partitions' => '',
  'num_time_travel_physical_bytes' => '',
  'num_total_logical_bytes' => '',
  'num_total_physical_bytes' => '',
  'rangePartitioning' => [
    'field' => '',
    'range' => [
        'end' => '',
        'interval' => '',
        'start' => ''
    ]
  ],
  'requirePartitionFilter' => null,
  'schema' => [
    
  ],
  'selfLink' => '',
  'snapshotDefinition' => [
    'baseTableReference' => [
        
    ],
    'snapshotTime' => ''
  ],
  'streamingBuffer' => [
    'estimatedBytes' => '',
    'estimatedRows' => '',
    'oldestEntryTime' => ''
  ],
  'tableReference' => [
    
  ],
  'timePartitioning' => [
    'expirationMs' => '',
    'field' => '',
    'requirePartitionFilter' => null,
    'type' => ''
  ],
  'type' => '',
  'view' => [
    'query' => '',
    'useExplicitColumnNames' => null,
    'useLegacySql' => null,
    'userDefinedFunctionResources' => [
        [
                'inlineCode' => '',
                'resourceUri' => ''
        ]
    ]
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cloneDefinition' => [
    'baseTableReference' => [
        'datasetId' => '',
        'projectId' => '',
        'tableId' => ''
    ],
    'cloneTime' => ''
  ],
  'clustering' => [
    'fields' => [
        
    ]
  ],
  'creationTime' => '',
  'defaultCollation' => '',
  'defaultRoundingMode' => '',
  'description' => '',
  'encryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'etag' => '',
  'expirationTime' => '',
  'externalDataConfiguration' => [
    'autodetect' => null,
    'avroOptions' => [
        'useAvroLogicalTypes' => null
    ],
    'bigtableOptions' => [
        'columnFamilies' => [
                [
                                'columns' => [
                                                                [
                                                                                                                                'encoding' => '',
                                                                                                                                'fieldName' => '',
                                                                                                                                'onlyReadLatest' => null,
                                                                                                                                'qualifierEncoded' => '',
                                                                                                                                'qualifierString' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'encoding' => '',
                                'familyId' => '',
                                'onlyReadLatest' => null,
                                'type' => ''
                ]
        ],
        'ignoreUnspecifiedColumnFamilies' => null,
        'readRowkeyAsString' => null
    ],
    'compression' => '',
    'connectionId' => '',
    'csvOptions' => [
        'allowJaggedRows' => null,
        'allowQuotedNewlines' => null,
        'encoding' => '',
        'fieldDelimiter' => '',
        'null_marker' => '',
        'preserveAsciiControlCharacters' => null,
        'quote' => '',
        'skipLeadingRows' => ''
    ],
    'decimalTargetTypes' => [
        
    ],
    'googleSheetsOptions' => [
        'range' => '',
        'skipLeadingRows' => ''
    ],
    'hivePartitioningOptions' => [
        'mode' => '',
        'requirePartitionFilter' => null,
        'sourceUriPrefix' => ''
    ],
    'ignoreUnknownValues' => null,
    'maxBadRecords' => 0,
    'metadataCacheMode' => '',
    'objectMetadata' => '',
    'parquetOptions' => [
        'enableListInference' => null,
        'enumAsString' => null
    ],
    'referenceFileSchemaUri' => '',
    'schema' => [
        'fields' => [
                [
                                'categories' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'collation' => '',
                                'defaultValueExpression' => '',
                                'description' => '',
                                'fields' => [
                                                                
                                ],
                                'maxLength' => '',
                                'mode' => '',
                                'name' => '',
                                'policyTags' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'precision' => '',
                                'roundingMode' => '',
                                'scale' => '',
                                'type' => ''
                ]
        ]
    ],
    'sourceFormat' => '',
    'sourceUris' => [
        
    ]
  ],
  'friendlyName' => '',
  'id' => '',
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'materializedView' => [
    'allow_non_incremental_definition' => null,
    'enableRefresh' => null,
    'lastRefreshTime' => '',
    'maxStaleness' => '',
    'query' => '',
    'refreshIntervalMs' => ''
  ],
  'maxStaleness' => '',
  'model' => [
    'modelOptions' => [
        'labels' => [
                
        ],
        'lossType' => '',
        'modelType' => ''
    ],
    'trainingRuns' => [
        [
                'iterationResults' => [
                                [
                                                                'durationMs' => '',
                                                                'evalLoss' => '',
                                                                'index' => 0,
                                                                'learnRate' => '',
                                                                'trainingLoss' => ''
                                ]
                ],
                'startTime' => '',
                'state' => '',
                'trainingOptions' => [
                                'earlyStop' => null,
                                'l1Reg' => '',
                                'l2Reg' => '',
                                'learnRate' => '',
                                'learnRateStrategy' => '',
                                'lineSearchInitLearnRate' => '',
                                'maxIteration' => '',
                                'minRelProgress' => '',
                                'warmStart' => null
                ]
        ]
    ]
  ],
  'numBytes' => '',
  'numLongTermBytes' => '',
  'numPhysicalBytes' => '',
  'numRows' => '',
  'num_active_logical_bytes' => '',
  'num_active_physical_bytes' => '',
  'num_long_term_logical_bytes' => '',
  'num_long_term_physical_bytes' => '',
  'num_partitions' => '',
  'num_time_travel_physical_bytes' => '',
  'num_total_logical_bytes' => '',
  'num_total_physical_bytes' => '',
  'rangePartitioning' => [
    'field' => '',
    'range' => [
        'end' => '',
        'interval' => '',
        'start' => ''
    ]
  ],
  'requirePartitionFilter' => null,
  'schema' => [
    
  ],
  'selfLink' => '',
  'snapshotDefinition' => [
    'baseTableReference' => [
        
    ],
    'snapshotTime' => ''
  ],
  'streamingBuffer' => [
    'estimatedBytes' => '',
    'estimatedRows' => '',
    'oldestEntryTime' => ''
  ],
  'tableReference' => [
    
  ],
  'timePartitioning' => [
    'expirationMs' => '',
    'field' => '',
    'requirePartitionFilter' => null,
    'type' => ''
  ],
  'type' => '',
  'view' => [
    'query' => '',
    'useExplicitColumnNames' => null,
    'useLegacySql' => null,
    'userDefinedFunctionResources' => [
        [
                'inlineCode' => '',
                'resourceUri' => ''
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables');
$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}}/projects/:projectId/datasets/:datasetId/tables' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}'
import http.client

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

payload = "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}"

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

conn.request("POST", "/baseUrl/projects/:projectId/datasets/:datasetId/tables", payload, headers)

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

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

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables"

payload = {
    "cloneDefinition": {
        "baseTableReference": {
            "datasetId": "",
            "projectId": "",
            "tableId": ""
        },
        "cloneTime": ""
    },
    "clustering": { "fields": [] },
    "creationTime": "",
    "defaultCollation": "",
    "defaultRoundingMode": "",
    "description": "",
    "encryptionConfiguration": { "kmsKeyName": "" },
    "etag": "",
    "expirationTime": "",
    "externalDataConfiguration": {
        "autodetect": False,
        "avroOptions": { "useAvroLogicalTypes": False },
        "bigtableOptions": {
            "columnFamilies": [
                {
                    "columns": [
                        {
                            "encoding": "",
                            "fieldName": "",
                            "onlyReadLatest": False,
                            "qualifierEncoded": "",
                            "qualifierString": "",
                            "type": ""
                        }
                    ],
                    "encoding": "",
                    "familyId": "",
                    "onlyReadLatest": False,
                    "type": ""
                }
            ],
            "ignoreUnspecifiedColumnFamilies": False,
            "readRowkeyAsString": False
        },
        "compression": "",
        "connectionId": "",
        "csvOptions": {
            "allowJaggedRows": False,
            "allowQuotedNewlines": False,
            "encoding": "",
            "fieldDelimiter": "",
            "null_marker": "",
            "preserveAsciiControlCharacters": False,
            "quote": "",
            "skipLeadingRows": ""
        },
        "decimalTargetTypes": [],
        "googleSheetsOptions": {
            "range": "",
            "skipLeadingRows": ""
        },
        "hivePartitioningOptions": {
            "mode": "",
            "requirePartitionFilter": False,
            "sourceUriPrefix": ""
        },
        "ignoreUnknownValues": False,
        "maxBadRecords": 0,
        "metadataCacheMode": "",
        "objectMetadata": "",
        "parquetOptions": {
            "enableListInference": False,
            "enumAsString": False
        },
        "referenceFileSchemaUri": "",
        "schema": { "fields": [
                {
                    "categories": { "names": [] },
                    "collation": "",
                    "defaultValueExpression": "",
                    "description": "",
                    "fields": [],
                    "maxLength": "",
                    "mode": "",
                    "name": "",
                    "policyTags": { "names": [] },
                    "precision": "",
                    "roundingMode": "",
                    "scale": "",
                    "type": ""
                }
            ] },
        "sourceFormat": "",
        "sourceUris": []
    },
    "friendlyName": "",
    "id": "",
    "kind": "",
    "labels": {},
    "lastModifiedTime": "",
    "location": "",
    "materializedView": {
        "allow_non_incremental_definition": False,
        "enableRefresh": False,
        "lastRefreshTime": "",
        "maxStaleness": "",
        "query": "",
        "refreshIntervalMs": ""
    },
    "maxStaleness": "",
    "model": {
        "modelOptions": {
            "labels": [],
            "lossType": "",
            "modelType": ""
        },
        "trainingRuns": [
            {
                "iterationResults": [
                    {
                        "durationMs": "",
                        "evalLoss": "",
                        "index": 0,
                        "learnRate": "",
                        "trainingLoss": ""
                    }
                ],
                "startTime": "",
                "state": "",
                "trainingOptions": {
                    "earlyStop": False,
                    "l1Reg": "",
                    "l2Reg": "",
                    "learnRate": "",
                    "learnRateStrategy": "",
                    "lineSearchInitLearnRate": "",
                    "maxIteration": "",
                    "minRelProgress": "",
                    "warmStart": False
                }
            }
        ]
    },
    "numBytes": "",
    "numLongTermBytes": "",
    "numPhysicalBytes": "",
    "numRows": "",
    "num_active_logical_bytes": "",
    "num_active_physical_bytes": "",
    "num_long_term_logical_bytes": "",
    "num_long_term_physical_bytes": "",
    "num_partitions": "",
    "num_time_travel_physical_bytes": "",
    "num_total_logical_bytes": "",
    "num_total_physical_bytes": "",
    "rangePartitioning": {
        "field": "",
        "range": {
            "end": "",
            "interval": "",
            "start": ""
        }
    },
    "requirePartitionFilter": False,
    "schema": {},
    "selfLink": "",
    "snapshotDefinition": {
        "baseTableReference": {},
        "snapshotTime": ""
    },
    "streamingBuffer": {
        "estimatedBytes": "",
        "estimatedRows": "",
        "oldestEntryTime": ""
    },
    "tableReference": {},
    "timePartitioning": {
        "expirationMs": "",
        "field": "",
        "requirePartitionFilter": False,
        "type": ""
    },
    "type": "",
    "view": {
        "query": "",
        "useExplicitColumnNames": False,
        "useLegacySql": False,
        "userDefinedFunctionResources": [
            {
                "inlineCode": "",
                "resourceUri": ""
            }
        ]
    }
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables"

payload <- "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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}}/projects/:projectId/datasets/:datasetId/tables")

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  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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/projects/:projectId/datasets/:datasetId/tables') do |req|
  req.body = "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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}}/projects/:projectId/datasets/:datasetId/tables";

    let payload = json!({
        "cloneDefinition": json!({
            "baseTableReference": json!({
                "datasetId": "",
                "projectId": "",
                "tableId": ""
            }),
            "cloneTime": ""
        }),
        "clustering": json!({"fields": ()}),
        "creationTime": "",
        "defaultCollation": "",
        "defaultRoundingMode": "",
        "description": "",
        "encryptionConfiguration": json!({"kmsKeyName": ""}),
        "etag": "",
        "expirationTime": "",
        "externalDataConfiguration": json!({
            "autodetect": false,
            "avroOptions": json!({"useAvroLogicalTypes": false}),
            "bigtableOptions": json!({
                "columnFamilies": (
                    json!({
                        "columns": (
                            json!({
                                "encoding": "",
                                "fieldName": "",
                                "onlyReadLatest": false,
                                "qualifierEncoded": "",
                                "qualifierString": "",
                                "type": ""
                            })
                        ),
                        "encoding": "",
                        "familyId": "",
                        "onlyReadLatest": false,
                        "type": ""
                    })
                ),
                "ignoreUnspecifiedColumnFamilies": false,
                "readRowkeyAsString": false
            }),
            "compression": "",
            "connectionId": "",
            "csvOptions": json!({
                "allowJaggedRows": false,
                "allowQuotedNewlines": false,
                "encoding": "",
                "fieldDelimiter": "",
                "null_marker": "",
                "preserveAsciiControlCharacters": false,
                "quote": "",
                "skipLeadingRows": ""
            }),
            "decimalTargetTypes": (),
            "googleSheetsOptions": json!({
                "range": "",
                "skipLeadingRows": ""
            }),
            "hivePartitioningOptions": json!({
                "mode": "",
                "requirePartitionFilter": false,
                "sourceUriPrefix": ""
            }),
            "ignoreUnknownValues": false,
            "maxBadRecords": 0,
            "metadataCacheMode": "",
            "objectMetadata": "",
            "parquetOptions": json!({
                "enableListInference": false,
                "enumAsString": false
            }),
            "referenceFileSchemaUri": "",
            "schema": json!({"fields": (
                    json!({
                        "categories": json!({"names": ()}),
                        "collation": "",
                        "defaultValueExpression": "",
                        "description": "",
                        "fields": (),
                        "maxLength": "",
                        "mode": "",
                        "name": "",
                        "policyTags": json!({"names": ()}),
                        "precision": "",
                        "roundingMode": "",
                        "scale": "",
                        "type": ""
                    })
                )}),
            "sourceFormat": "",
            "sourceUris": ()
        }),
        "friendlyName": "",
        "id": "",
        "kind": "",
        "labels": json!({}),
        "lastModifiedTime": "",
        "location": "",
        "materializedView": json!({
            "allow_non_incremental_definition": false,
            "enableRefresh": false,
            "lastRefreshTime": "",
            "maxStaleness": "",
            "query": "",
            "refreshIntervalMs": ""
        }),
        "maxStaleness": "",
        "model": json!({
            "modelOptions": json!({
                "labels": (),
                "lossType": "",
                "modelType": ""
            }),
            "trainingRuns": (
                json!({
                    "iterationResults": (
                        json!({
                            "durationMs": "",
                            "evalLoss": "",
                            "index": 0,
                            "learnRate": "",
                            "trainingLoss": ""
                        })
                    ),
                    "startTime": "",
                    "state": "",
                    "trainingOptions": json!({
                        "earlyStop": false,
                        "l1Reg": "",
                        "l2Reg": "",
                        "learnRate": "",
                        "learnRateStrategy": "",
                        "lineSearchInitLearnRate": "",
                        "maxIteration": "",
                        "minRelProgress": "",
                        "warmStart": false
                    })
                })
            )
        }),
        "numBytes": "",
        "numLongTermBytes": "",
        "numPhysicalBytes": "",
        "numRows": "",
        "num_active_logical_bytes": "",
        "num_active_physical_bytes": "",
        "num_long_term_logical_bytes": "",
        "num_long_term_physical_bytes": "",
        "num_partitions": "",
        "num_time_travel_physical_bytes": "",
        "num_total_logical_bytes": "",
        "num_total_physical_bytes": "",
        "rangePartitioning": json!({
            "field": "",
            "range": json!({
                "end": "",
                "interval": "",
                "start": ""
            })
        }),
        "requirePartitionFilter": false,
        "schema": json!({}),
        "selfLink": "",
        "snapshotDefinition": json!({
            "baseTableReference": json!({}),
            "snapshotTime": ""
        }),
        "streamingBuffer": json!({
            "estimatedBytes": "",
            "estimatedRows": "",
            "oldestEntryTime": ""
        }),
        "tableReference": json!({}),
        "timePartitioning": json!({
            "expirationMs": "",
            "field": "",
            "requirePartitionFilter": false,
            "type": ""
        }),
        "type": "",
        "view": json!({
            "query": "",
            "useExplicitColumnNames": false,
            "useLegacySql": false,
            "userDefinedFunctionResources": (
                json!({
                    "inlineCode": "",
                    "resourceUri": ""
                })
            )
        })
    });

    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}}/projects/:projectId/datasets/:datasetId/tables \
  --header 'content-type: application/json' \
  --data '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}'
echo '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}' |  \
  http POST {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "cloneDefinition": {\n    "baseTableReference": {\n      "datasetId": "",\n      "projectId": "",\n      "tableId": ""\n    },\n    "cloneTime": ""\n  },\n  "clustering": {\n    "fields": []\n  },\n  "creationTime": "",\n  "defaultCollation": "",\n  "defaultRoundingMode": "",\n  "description": "",\n  "encryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "etag": "",\n  "expirationTime": "",\n  "externalDataConfiguration": {\n    "autodetect": false,\n    "avroOptions": {\n      "useAvroLogicalTypes": false\n    },\n    "bigtableOptions": {\n      "columnFamilies": [\n        {\n          "columns": [\n            {\n              "encoding": "",\n              "fieldName": "",\n              "onlyReadLatest": false,\n              "qualifierEncoded": "",\n              "qualifierString": "",\n              "type": ""\n            }\n          ],\n          "encoding": "",\n          "familyId": "",\n          "onlyReadLatest": false,\n          "type": ""\n        }\n      ],\n      "ignoreUnspecifiedColumnFamilies": false,\n      "readRowkeyAsString": false\n    },\n    "compression": "",\n    "connectionId": "",\n    "csvOptions": {\n      "allowJaggedRows": false,\n      "allowQuotedNewlines": false,\n      "encoding": "",\n      "fieldDelimiter": "",\n      "null_marker": "",\n      "preserveAsciiControlCharacters": false,\n      "quote": "",\n      "skipLeadingRows": ""\n    },\n    "decimalTargetTypes": [],\n    "googleSheetsOptions": {\n      "range": "",\n      "skipLeadingRows": ""\n    },\n    "hivePartitioningOptions": {\n      "mode": "",\n      "requirePartitionFilter": false,\n      "sourceUriPrefix": ""\n    },\n    "ignoreUnknownValues": false,\n    "maxBadRecords": 0,\n    "metadataCacheMode": "",\n    "objectMetadata": "",\n    "parquetOptions": {\n      "enableListInference": false,\n      "enumAsString": false\n    },\n    "referenceFileSchemaUri": "",\n    "schema": {\n      "fields": [\n        {\n          "categories": {\n            "names": []\n          },\n          "collation": "",\n          "defaultValueExpression": "",\n          "description": "",\n          "fields": [],\n          "maxLength": "",\n          "mode": "",\n          "name": "",\n          "policyTags": {\n            "names": []\n          },\n          "precision": "",\n          "roundingMode": "",\n          "scale": "",\n          "type": ""\n        }\n      ]\n    },\n    "sourceFormat": "",\n    "sourceUris": []\n  },\n  "friendlyName": "",\n  "id": "",\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "materializedView": {\n    "allow_non_incremental_definition": false,\n    "enableRefresh": false,\n    "lastRefreshTime": "",\n    "maxStaleness": "",\n    "query": "",\n    "refreshIntervalMs": ""\n  },\n  "maxStaleness": "",\n  "model": {\n    "modelOptions": {\n      "labels": [],\n      "lossType": "",\n      "modelType": ""\n    },\n    "trainingRuns": [\n      {\n        "iterationResults": [\n          {\n            "durationMs": "",\n            "evalLoss": "",\n            "index": 0,\n            "learnRate": "",\n            "trainingLoss": ""\n          }\n        ],\n        "startTime": "",\n        "state": "",\n        "trainingOptions": {\n          "earlyStop": false,\n          "l1Reg": "",\n          "l2Reg": "",\n          "learnRate": "",\n          "learnRateStrategy": "",\n          "lineSearchInitLearnRate": "",\n          "maxIteration": "",\n          "minRelProgress": "",\n          "warmStart": false\n        }\n      }\n    ]\n  },\n  "numBytes": "",\n  "numLongTermBytes": "",\n  "numPhysicalBytes": "",\n  "numRows": "",\n  "num_active_logical_bytes": "",\n  "num_active_physical_bytes": "",\n  "num_long_term_logical_bytes": "",\n  "num_long_term_physical_bytes": "",\n  "num_partitions": "",\n  "num_time_travel_physical_bytes": "",\n  "num_total_logical_bytes": "",\n  "num_total_physical_bytes": "",\n  "rangePartitioning": {\n    "field": "",\n    "range": {\n      "end": "",\n      "interval": "",\n      "start": ""\n    }\n  },\n  "requirePartitionFilter": false,\n  "schema": {},\n  "selfLink": "",\n  "snapshotDefinition": {\n    "baseTableReference": {},\n    "snapshotTime": ""\n  },\n  "streamingBuffer": {\n    "estimatedBytes": "",\n    "estimatedRows": "",\n    "oldestEntryTime": ""\n  },\n  "tableReference": {},\n  "timePartitioning": {\n    "expirationMs": "",\n    "field": "",\n    "requirePartitionFilter": false,\n    "type": ""\n  },\n  "type": "",\n  "view": {\n    "query": "",\n    "useExplicitColumnNames": false,\n    "useLegacySql": false,\n    "userDefinedFunctionResources": [\n      {\n        "inlineCode": "",\n        "resourceUri": ""\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "cloneDefinition": [
    "baseTableReference": [
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    ],
    "cloneTime": ""
  ],
  "clustering": ["fields": []],
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": ["kmsKeyName": ""],
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": [
    "autodetect": false,
    "avroOptions": ["useAvroLogicalTypes": false],
    "bigtableOptions": [
      "columnFamilies": [
        [
          "columns": [
            [
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            ]
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        ]
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    ],
    "compression": "",
    "connectionId": "",
    "csvOptions": [
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    ],
    "decimalTargetTypes": [],
    "googleSheetsOptions": [
      "range": "",
      "skipLeadingRows": ""
    ],
    "hivePartitioningOptions": [
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    ],
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": [
      "enableListInference": false,
      "enumAsString": false
    ],
    "referenceFileSchemaUri": "",
    "schema": ["fields": [
        [
          "categories": ["names": []],
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": ["names": []],
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        ]
      ]],
    "sourceFormat": "",
    "sourceUris": []
  ],
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": [],
  "lastModifiedTime": "",
  "location": "",
  "materializedView": [
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  ],
  "maxStaleness": "",
  "model": [
    "modelOptions": [
      "labels": [],
      "lossType": "",
      "modelType": ""
    ],
    "trainingRuns": [
      [
        "iterationResults": [
          [
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          ]
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": [
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        ]
      ]
    ]
  ],
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": [
    "field": "",
    "range": [
      "end": "",
      "interval": "",
      "start": ""
    ]
  ],
  "requirePartitionFilter": false,
  "schema": [],
  "selfLink": "",
  "snapshotDefinition": [
    "baseTableReference": [],
    "snapshotTime": ""
  ],
  "streamingBuffer": [
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  ],
  "tableReference": [],
  "timePartitioning": [
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  ],
  "type": "",
  "view": [
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      [
        "inlineCode": "",
        "resourceUri": ""
      ]
    ]
  ]
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables")! 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 bigquery.tables.list
{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables
QUERY PARAMS

projectId
datasetId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables");

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

(client/get "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables")
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables"

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

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

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables"

	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/projects/:projectId/datasets/:datasetId/tables HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables")
  .asString();
const 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}}/projects/:projectId/datasets/:datasetId/tables');

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/tables',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.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}}/projects/:projectId/datasets/:datasetId/tables'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables');

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}}/projects/:projectId/datasets/:datasetId/tables'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables';
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}}/projects/:projectId/datasets/:datasetId/tables"]
                                                       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}}/projects/:projectId/datasets/:datasetId/tables" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables",
  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}}/projects/:projectId/datasets/:datasetId/tables');

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/projects/:projectId/datasets/:datasetId/tables")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables")

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/projects/:projectId/datasets/:datasetId/tables') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables";

    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}}/projects/:projectId/datasets/:datasetId/tables
http GET {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables")! 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 bigquery.tables.patch
{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId
QUERY PARAMS

projectId
datasetId
tableId
BODY json

{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/patch "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId" {:content-type :json
                                                                                                     :form-params {:cloneDefinition {:baseTableReference {:datasetId ""
                                                                                                                                                          :projectId ""
                                                                                                                                                          :tableId ""}
                                                                                                                                     :cloneTime ""}
                                                                                                                   :clustering {:fields []}
                                                                                                                   :creationTime ""
                                                                                                                   :defaultCollation ""
                                                                                                                   :defaultRoundingMode ""
                                                                                                                   :description ""
                                                                                                                   :encryptionConfiguration {:kmsKeyName ""}
                                                                                                                   :etag ""
                                                                                                                   :expirationTime ""
                                                                                                                   :externalDataConfiguration {:autodetect false
                                                                                                                                               :avroOptions {:useAvroLogicalTypes false}
                                                                                                                                               :bigtableOptions {:columnFamilies [{:columns [{:encoding ""
                                                                                                                                                                                              :fieldName ""
                                                                                                                                                                                              :onlyReadLatest false
                                                                                                                                                                                              :qualifierEncoded ""
                                                                                                                                                                                              :qualifierString ""
                                                                                                                                                                                              :type ""}]
                                                                                                                                                                                   :encoding ""
                                                                                                                                                                                   :familyId ""
                                                                                                                                                                                   :onlyReadLatest false
                                                                                                                                                                                   :type ""}]
                                                                                                                                                                 :ignoreUnspecifiedColumnFamilies false
                                                                                                                                                                 :readRowkeyAsString false}
                                                                                                                                               :compression ""
                                                                                                                                               :connectionId ""
                                                                                                                                               :csvOptions {:allowJaggedRows false
                                                                                                                                                            :allowQuotedNewlines false
                                                                                                                                                            :encoding ""
                                                                                                                                                            :fieldDelimiter ""
                                                                                                                                                            :null_marker ""
                                                                                                                                                            :preserveAsciiControlCharacters false
                                                                                                                                                            :quote ""
                                                                                                                                                            :skipLeadingRows ""}
                                                                                                                                               :decimalTargetTypes []
                                                                                                                                               :googleSheetsOptions {:range ""
                                                                                                                                                                     :skipLeadingRows ""}
                                                                                                                                               :hivePartitioningOptions {:mode ""
                                                                                                                                                                         :requirePartitionFilter false
                                                                                                                                                                         :sourceUriPrefix ""}
                                                                                                                                               :ignoreUnknownValues false
                                                                                                                                               :maxBadRecords 0
                                                                                                                                               :metadataCacheMode ""
                                                                                                                                               :objectMetadata ""
                                                                                                                                               :parquetOptions {:enableListInference false
                                                                                                                                                                :enumAsString false}
                                                                                                                                               :referenceFileSchemaUri ""
                                                                                                                                               :schema {:fields [{:categories {:names []}
                                                                                                                                                                  :collation ""
                                                                                                                                                                  :defaultValueExpression ""
                                                                                                                                                                  :description ""
                                                                                                                                                                  :fields []
                                                                                                                                                                  :maxLength ""
                                                                                                                                                                  :mode ""
                                                                                                                                                                  :name ""
                                                                                                                                                                  :policyTags {:names []}
                                                                                                                                                                  :precision ""
                                                                                                                                                                  :roundingMode ""
                                                                                                                                                                  :scale ""
                                                                                                                                                                  :type ""}]}
                                                                                                                                               :sourceFormat ""
                                                                                                                                               :sourceUris []}
                                                                                                                   :friendlyName ""
                                                                                                                   :id ""
                                                                                                                   :kind ""
                                                                                                                   :labels {}
                                                                                                                   :lastModifiedTime ""
                                                                                                                   :location ""
                                                                                                                   :materializedView {:allow_non_incremental_definition false
                                                                                                                                      :enableRefresh false
                                                                                                                                      :lastRefreshTime ""
                                                                                                                                      :maxStaleness ""
                                                                                                                                      :query ""
                                                                                                                                      :refreshIntervalMs ""}
                                                                                                                   :maxStaleness ""
                                                                                                                   :model {:modelOptions {:labels []
                                                                                                                                          :lossType ""
                                                                                                                                          :modelType ""}
                                                                                                                           :trainingRuns [{:iterationResults [{:durationMs ""
                                                                                                                                                               :evalLoss ""
                                                                                                                                                               :index 0
                                                                                                                                                               :learnRate ""
                                                                                                                                                               :trainingLoss ""}]
                                                                                                                                           :startTime ""
                                                                                                                                           :state ""
                                                                                                                                           :trainingOptions {:earlyStop false
                                                                                                                                                             :l1Reg ""
                                                                                                                                                             :l2Reg ""
                                                                                                                                                             :learnRate ""
                                                                                                                                                             :learnRateStrategy ""
                                                                                                                                                             :lineSearchInitLearnRate ""
                                                                                                                                                             :maxIteration ""
                                                                                                                                                             :minRelProgress ""
                                                                                                                                                             :warmStart false}}]}
                                                                                                                   :numBytes ""
                                                                                                                   :numLongTermBytes ""
                                                                                                                   :numPhysicalBytes ""
                                                                                                                   :numRows ""
                                                                                                                   :num_active_logical_bytes ""
                                                                                                                   :num_active_physical_bytes ""
                                                                                                                   :num_long_term_logical_bytes ""
                                                                                                                   :num_long_term_physical_bytes ""
                                                                                                                   :num_partitions ""
                                                                                                                   :num_time_travel_physical_bytes ""
                                                                                                                   :num_total_logical_bytes ""
                                                                                                                   :num_total_physical_bytes ""
                                                                                                                   :rangePartitioning {:field ""
                                                                                                                                       :range {:end ""
                                                                                                                                               :interval ""
                                                                                                                                               :start ""}}
                                                                                                                   :requirePartitionFilter false
                                                                                                                   :schema {}
                                                                                                                   :selfLink ""
                                                                                                                   :snapshotDefinition {:baseTableReference {}
                                                                                                                                        :snapshotTime ""}
                                                                                                                   :streamingBuffer {:estimatedBytes ""
                                                                                                                                     :estimatedRows ""
                                                                                                                                     :oldestEntryTime ""}
                                                                                                                   :tableReference {}
                                                                                                                   :timePartitioning {:expirationMs ""
                                                                                                                                      :field ""
                                                                                                                                      :requirePartitionFilter false
                                                                                                                                      :type ""}
                                                                                                                   :type ""
                                                                                                                   :view {:query ""
                                                                                                                          :useExplicitColumnNames false
                                                                                                                          :useLegacySql false
                                                                                                                          :userDefinedFunctionResources [{:inlineCode ""
                                                                                                                                                          :resourceUri ""}]}}})
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\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}}/projects/:projectId/datasets/:datasetId/tables/:tableId"),
    Content = new StringContent("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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}}/projects/:projectId/datasets/:datasetId/tables/:tableId");
var request = new RestRequest("", Method.Patch);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

	payload := strings.NewReader("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\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/projects/:projectId/datasets/:datasetId/tables/:tableId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 4536

{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"))
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .patch(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .header("content-type", "application/json")
  .body("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  cloneDefinition: {
    baseTableReference: {
      datasetId: '',
      projectId: '',
      tableId: ''
    },
    cloneTime: ''
  },
  clustering: {
    fields: []
  },
  creationTime: '',
  defaultCollation: '',
  defaultRoundingMode: '',
  description: '',
  encryptionConfiguration: {
    kmsKeyName: ''
  },
  etag: '',
  expirationTime: '',
  externalDataConfiguration: {
    autodetect: false,
    avroOptions: {
      useAvroLogicalTypes: false
    },
    bigtableOptions: {
      columnFamilies: [
        {
          columns: [
            {
              encoding: '',
              fieldName: '',
              onlyReadLatest: false,
              qualifierEncoded: '',
              qualifierString: '',
              type: ''
            }
          ],
          encoding: '',
          familyId: '',
          onlyReadLatest: false,
          type: ''
        }
      ],
      ignoreUnspecifiedColumnFamilies: false,
      readRowkeyAsString: false
    },
    compression: '',
    connectionId: '',
    csvOptions: {
      allowJaggedRows: false,
      allowQuotedNewlines: false,
      encoding: '',
      fieldDelimiter: '',
      null_marker: '',
      preserveAsciiControlCharacters: false,
      quote: '',
      skipLeadingRows: ''
    },
    decimalTargetTypes: [],
    googleSheetsOptions: {
      range: '',
      skipLeadingRows: ''
    },
    hivePartitioningOptions: {
      mode: '',
      requirePartitionFilter: false,
      sourceUriPrefix: ''
    },
    ignoreUnknownValues: false,
    maxBadRecords: 0,
    metadataCacheMode: '',
    objectMetadata: '',
    parquetOptions: {
      enableListInference: false,
      enumAsString: false
    },
    referenceFileSchemaUri: '',
    schema: {
      fields: [
        {
          categories: {
            names: []
          },
          collation: '',
          defaultValueExpression: '',
          description: '',
          fields: [],
          maxLength: '',
          mode: '',
          name: '',
          policyTags: {
            names: []
          },
          precision: '',
          roundingMode: '',
          scale: '',
          type: ''
        }
      ]
    },
    sourceFormat: '',
    sourceUris: []
  },
  friendlyName: '',
  id: '',
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  materializedView: {
    allow_non_incremental_definition: false,
    enableRefresh: false,
    lastRefreshTime: '',
    maxStaleness: '',
    query: '',
    refreshIntervalMs: ''
  },
  maxStaleness: '',
  model: {
    modelOptions: {
      labels: [],
      lossType: '',
      modelType: ''
    },
    trainingRuns: [
      {
        iterationResults: [
          {
            durationMs: '',
            evalLoss: '',
            index: 0,
            learnRate: '',
            trainingLoss: ''
          }
        ],
        startTime: '',
        state: '',
        trainingOptions: {
          earlyStop: false,
          l1Reg: '',
          l2Reg: '',
          learnRate: '',
          learnRateStrategy: '',
          lineSearchInitLearnRate: '',
          maxIteration: '',
          minRelProgress: '',
          warmStart: false
        }
      }
    ]
  },
  numBytes: '',
  numLongTermBytes: '',
  numPhysicalBytes: '',
  numRows: '',
  num_active_logical_bytes: '',
  num_active_physical_bytes: '',
  num_long_term_logical_bytes: '',
  num_long_term_physical_bytes: '',
  num_partitions: '',
  num_time_travel_physical_bytes: '',
  num_total_logical_bytes: '',
  num_total_physical_bytes: '',
  rangePartitioning: {
    field: '',
    range: {
      end: '',
      interval: '',
      start: ''
    }
  },
  requirePartitionFilter: false,
  schema: {},
  selfLink: '',
  snapshotDefinition: {
    baseTableReference: {},
    snapshotTime: ''
  },
  streamingBuffer: {
    estimatedBytes: '',
    estimatedRows: '',
    oldestEntryTime: ''
  },
  tableReference: {},
  timePartitioning: {
    expirationMs: '',
    field: '',
    requirePartitionFilter: false,
    type: ''
  },
  type: '',
  view: {
    query: '',
    useExplicitColumnNames: false,
    useLegacySql: false,
    userDefinedFunctionResources: [
      {
        inlineCode: '',
        resourceUri: ''
      }
    ]
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PATCH', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId',
  headers: {'content-type': 'application/json'},
  data: {
    cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
    clustering: {fields: []},
    creationTime: '',
    defaultCollation: '',
    defaultRoundingMode: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    externalDataConfiguration: {
      autodetect: false,
      avroOptions: {useAvroLogicalTypes: false},
      bigtableOptions: {
        columnFamilies: [
          {
            columns: [
              {
                encoding: '',
                fieldName: '',
                onlyReadLatest: false,
                qualifierEncoded: '',
                qualifierString: '',
                type: ''
              }
            ],
            encoding: '',
            familyId: '',
            onlyReadLatest: false,
            type: ''
          }
        ],
        ignoreUnspecifiedColumnFamilies: false,
        readRowkeyAsString: false
      },
      compression: '',
      connectionId: '',
      csvOptions: {
        allowJaggedRows: false,
        allowQuotedNewlines: false,
        encoding: '',
        fieldDelimiter: '',
        null_marker: '',
        preserveAsciiControlCharacters: false,
        quote: '',
        skipLeadingRows: ''
      },
      decimalTargetTypes: [],
      googleSheetsOptions: {range: '', skipLeadingRows: ''},
      hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
      ignoreUnknownValues: false,
      maxBadRecords: 0,
      metadataCacheMode: '',
      objectMetadata: '',
      parquetOptions: {enableListInference: false, enumAsString: false},
      referenceFileSchemaUri: '',
      schema: {
        fields: [
          {
            categories: {names: []},
            collation: '',
            defaultValueExpression: '',
            description: '',
            fields: [],
            maxLength: '',
            mode: '',
            name: '',
            policyTags: {names: []},
            precision: '',
            roundingMode: '',
            scale: '',
            type: ''
          }
        ]
      },
      sourceFormat: '',
      sourceUris: []
    },
    friendlyName: '',
    id: '',
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    materializedView: {
      allow_non_incremental_definition: false,
      enableRefresh: false,
      lastRefreshTime: '',
      maxStaleness: '',
      query: '',
      refreshIntervalMs: ''
    },
    maxStaleness: '',
    model: {
      modelOptions: {labels: [], lossType: '', modelType: ''},
      trainingRuns: [
        {
          iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
          startTime: '',
          state: '',
          trainingOptions: {
            earlyStop: false,
            l1Reg: '',
            l2Reg: '',
            learnRate: '',
            learnRateStrategy: '',
            lineSearchInitLearnRate: '',
            maxIteration: '',
            minRelProgress: '',
            warmStart: false
          }
        }
      ]
    },
    numBytes: '',
    numLongTermBytes: '',
    numPhysicalBytes: '',
    numRows: '',
    num_active_logical_bytes: '',
    num_active_physical_bytes: '',
    num_long_term_logical_bytes: '',
    num_long_term_physical_bytes: '',
    num_partitions: '',
    num_time_travel_physical_bytes: '',
    num_total_logical_bytes: '',
    num_total_physical_bytes: '',
    rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
    requirePartitionFilter: false,
    schema: {},
    selfLink: '',
    snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
    streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
    tableReference: {},
    timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
    type: '',
    view: {
      query: '',
      useExplicitColumnNames: false,
      useLegacySql: false,
      userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"cloneDefinition":{"baseTableReference":{"datasetId":"","projectId":"","tableId":""},"cloneTime":""},"clustering":{"fields":[]},"creationTime":"","defaultCollation":"","defaultRoundingMode":"","description":"","encryptionConfiguration":{"kmsKeyName":""},"etag":"","expirationTime":"","externalDataConfiguration":{"autodetect":false,"avroOptions":{"useAvroLogicalTypes":false},"bigtableOptions":{"columnFamilies":[{"columns":[{"encoding":"","fieldName":"","onlyReadLatest":false,"qualifierEncoded":"","qualifierString":"","type":""}],"encoding":"","familyId":"","onlyReadLatest":false,"type":""}],"ignoreUnspecifiedColumnFamilies":false,"readRowkeyAsString":false},"compression":"","connectionId":"","csvOptions":{"allowJaggedRows":false,"allowQuotedNewlines":false,"encoding":"","fieldDelimiter":"","null_marker":"","preserveAsciiControlCharacters":false,"quote":"","skipLeadingRows":""},"decimalTargetTypes":[],"googleSheetsOptions":{"range":"","skipLeadingRows":""},"hivePartitioningOptions":{"mode":"","requirePartitionFilter":false,"sourceUriPrefix":""},"ignoreUnknownValues":false,"maxBadRecords":0,"metadataCacheMode":"","objectMetadata":"","parquetOptions":{"enableListInference":false,"enumAsString":false},"referenceFileSchemaUri":"","schema":{"fields":[{"categories":{"names":[]},"collation":"","defaultValueExpression":"","description":"","fields":[],"maxLength":"","mode":"","name":"","policyTags":{"names":[]},"precision":"","roundingMode":"","scale":"","type":""}]},"sourceFormat":"","sourceUris":[]},"friendlyName":"","id":"","kind":"","labels":{},"lastModifiedTime":"","location":"","materializedView":{"allow_non_incremental_definition":false,"enableRefresh":false,"lastRefreshTime":"","maxStaleness":"","query":"","refreshIntervalMs":""},"maxStaleness":"","model":{"modelOptions":{"labels":[],"lossType":"","modelType":""},"trainingRuns":[{"iterationResults":[{"durationMs":"","evalLoss":"","index":0,"learnRate":"","trainingLoss":""}],"startTime":"","state":"","trainingOptions":{"earlyStop":false,"l1Reg":"","l2Reg":"","learnRate":"","learnRateStrategy":"","lineSearchInitLearnRate":"","maxIteration":"","minRelProgress":"","warmStart":false}}]},"numBytes":"","numLongTermBytes":"","numPhysicalBytes":"","numRows":"","num_active_logical_bytes":"","num_active_physical_bytes":"","num_long_term_logical_bytes":"","num_long_term_physical_bytes":"","num_partitions":"","num_time_travel_physical_bytes":"","num_total_logical_bytes":"","num_total_physical_bytes":"","rangePartitioning":{"field":"","range":{"end":"","interval":"","start":""}},"requirePartitionFilter":false,"schema":{},"selfLink":"","snapshotDefinition":{"baseTableReference":{},"snapshotTime":""},"streamingBuffer":{"estimatedBytes":"","estimatedRows":"","oldestEntryTime":""},"tableReference":{},"timePartitioning":{"expirationMs":"","field":"","requirePartitionFilter":false,"type":""},"type":"","view":{"query":"","useExplicitColumnNames":false,"useLegacySql":false,"userDefinedFunctionResources":[{"inlineCode":"","resourceUri":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId',
  method: 'PATCH',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cloneDefinition": {\n    "baseTableReference": {\n      "datasetId": "",\n      "projectId": "",\n      "tableId": ""\n    },\n    "cloneTime": ""\n  },\n  "clustering": {\n    "fields": []\n  },\n  "creationTime": "",\n  "defaultCollation": "",\n  "defaultRoundingMode": "",\n  "description": "",\n  "encryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "etag": "",\n  "expirationTime": "",\n  "externalDataConfiguration": {\n    "autodetect": false,\n    "avroOptions": {\n      "useAvroLogicalTypes": false\n    },\n    "bigtableOptions": {\n      "columnFamilies": [\n        {\n          "columns": [\n            {\n              "encoding": "",\n              "fieldName": "",\n              "onlyReadLatest": false,\n              "qualifierEncoded": "",\n              "qualifierString": "",\n              "type": ""\n            }\n          ],\n          "encoding": "",\n          "familyId": "",\n          "onlyReadLatest": false,\n          "type": ""\n        }\n      ],\n      "ignoreUnspecifiedColumnFamilies": false,\n      "readRowkeyAsString": false\n    },\n    "compression": "",\n    "connectionId": "",\n    "csvOptions": {\n      "allowJaggedRows": false,\n      "allowQuotedNewlines": false,\n      "encoding": "",\n      "fieldDelimiter": "",\n      "null_marker": "",\n      "preserveAsciiControlCharacters": false,\n      "quote": "",\n      "skipLeadingRows": ""\n    },\n    "decimalTargetTypes": [],\n    "googleSheetsOptions": {\n      "range": "",\n      "skipLeadingRows": ""\n    },\n    "hivePartitioningOptions": {\n      "mode": "",\n      "requirePartitionFilter": false,\n      "sourceUriPrefix": ""\n    },\n    "ignoreUnknownValues": false,\n    "maxBadRecords": 0,\n    "metadataCacheMode": "",\n    "objectMetadata": "",\n    "parquetOptions": {\n      "enableListInference": false,\n      "enumAsString": false\n    },\n    "referenceFileSchemaUri": "",\n    "schema": {\n      "fields": [\n        {\n          "categories": {\n            "names": []\n          },\n          "collation": "",\n          "defaultValueExpression": "",\n          "description": "",\n          "fields": [],\n          "maxLength": "",\n          "mode": "",\n          "name": "",\n          "policyTags": {\n            "names": []\n          },\n          "precision": "",\n          "roundingMode": "",\n          "scale": "",\n          "type": ""\n        }\n      ]\n    },\n    "sourceFormat": "",\n    "sourceUris": []\n  },\n  "friendlyName": "",\n  "id": "",\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "materializedView": {\n    "allow_non_incremental_definition": false,\n    "enableRefresh": false,\n    "lastRefreshTime": "",\n    "maxStaleness": "",\n    "query": "",\n    "refreshIntervalMs": ""\n  },\n  "maxStaleness": "",\n  "model": {\n    "modelOptions": {\n      "labels": [],\n      "lossType": "",\n      "modelType": ""\n    },\n    "trainingRuns": [\n      {\n        "iterationResults": [\n          {\n            "durationMs": "",\n            "evalLoss": "",\n            "index": 0,\n            "learnRate": "",\n            "trainingLoss": ""\n          }\n        ],\n        "startTime": "",\n        "state": "",\n        "trainingOptions": {\n          "earlyStop": false,\n          "l1Reg": "",\n          "l2Reg": "",\n          "learnRate": "",\n          "learnRateStrategy": "",\n          "lineSearchInitLearnRate": "",\n          "maxIteration": "",\n          "minRelProgress": "",\n          "warmStart": false\n        }\n      }\n    ]\n  },\n  "numBytes": "",\n  "numLongTermBytes": "",\n  "numPhysicalBytes": "",\n  "numRows": "",\n  "num_active_logical_bytes": "",\n  "num_active_physical_bytes": "",\n  "num_long_term_logical_bytes": "",\n  "num_long_term_physical_bytes": "",\n  "num_partitions": "",\n  "num_time_travel_physical_bytes": "",\n  "num_total_logical_bytes": "",\n  "num_total_physical_bytes": "",\n  "rangePartitioning": {\n    "field": "",\n    "range": {\n      "end": "",\n      "interval": "",\n      "start": ""\n    }\n  },\n  "requirePartitionFilter": false,\n  "schema": {},\n  "selfLink": "",\n  "snapshotDefinition": {\n    "baseTableReference": {},\n    "snapshotTime": ""\n  },\n  "streamingBuffer": {\n    "estimatedBytes": "",\n    "estimatedRows": "",\n    "oldestEntryTime": ""\n  },\n  "tableReference": {},\n  "timePartitioning": {\n    "expirationMs": "",\n    "field": "",\n    "requirePartitionFilter": false,\n    "type": ""\n  },\n  "type": "",\n  "view": {\n    "query": "",\n    "useExplicitColumnNames": false,\n    "useLegacySql": false,\n    "userDefinedFunctionResources": [\n      {\n        "inlineCode": "",\n        "resourceUri": ""\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  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .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/projects/:projectId/datasets/:datasetId/tables/:tableId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
  clustering: {fields: []},
  creationTime: '',
  defaultCollation: '',
  defaultRoundingMode: '',
  description: '',
  encryptionConfiguration: {kmsKeyName: ''},
  etag: '',
  expirationTime: '',
  externalDataConfiguration: {
    autodetect: false,
    avroOptions: {useAvroLogicalTypes: false},
    bigtableOptions: {
      columnFamilies: [
        {
          columns: [
            {
              encoding: '',
              fieldName: '',
              onlyReadLatest: false,
              qualifierEncoded: '',
              qualifierString: '',
              type: ''
            }
          ],
          encoding: '',
          familyId: '',
          onlyReadLatest: false,
          type: ''
        }
      ],
      ignoreUnspecifiedColumnFamilies: false,
      readRowkeyAsString: false
    },
    compression: '',
    connectionId: '',
    csvOptions: {
      allowJaggedRows: false,
      allowQuotedNewlines: false,
      encoding: '',
      fieldDelimiter: '',
      null_marker: '',
      preserveAsciiControlCharacters: false,
      quote: '',
      skipLeadingRows: ''
    },
    decimalTargetTypes: [],
    googleSheetsOptions: {range: '', skipLeadingRows: ''},
    hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
    ignoreUnknownValues: false,
    maxBadRecords: 0,
    metadataCacheMode: '',
    objectMetadata: '',
    parquetOptions: {enableListInference: false, enumAsString: false},
    referenceFileSchemaUri: '',
    schema: {
      fields: [
        {
          categories: {names: []},
          collation: '',
          defaultValueExpression: '',
          description: '',
          fields: [],
          maxLength: '',
          mode: '',
          name: '',
          policyTags: {names: []},
          precision: '',
          roundingMode: '',
          scale: '',
          type: ''
        }
      ]
    },
    sourceFormat: '',
    sourceUris: []
  },
  friendlyName: '',
  id: '',
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  materializedView: {
    allow_non_incremental_definition: false,
    enableRefresh: false,
    lastRefreshTime: '',
    maxStaleness: '',
    query: '',
    refreshIntervalMs: ''
  },
  maxStaleness: '',
  model: {
    modelOptions: {labels: [], lossType: '', modelType: ''},
    trainingRuns: [
      {
        iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
        startTime: '',
        state: '',
        trainingOptions: {
          earlyStop: false,
          l1Reg: '',
          l2Reg: '',
          learnRate: '',
          learnRateStrategy: '',
          lineSearchInitLearnRate: '',
          maxIteration: '',
          minRelProgress: '',
          warmStart: false
        }
      }
    ]
  },
  numBytes: '',
  numLongTermBytes: '',
  numPhysicalBytes: '',
  numRows: '',
  num_active_logical_bytes: '',
  num_active_physical_bytes: '',
  num_long_term_logical_bytes: '',
  num_long_term_physical_bytes: '',
  num_partitions: '',
  num_time_travel_physical_bytes: '',
  num_total_logical_bytes: '',
  num_total_physical_bytes: '',
  rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
  requirePartitionFilter: false,
  schema: {},
  selfLink: '',
  snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
  streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
  tableReference: {},
  timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
  type: '',
  view: {
    query: '',
    useExplicitColumnNames: false,
    useLegacySql: false,
    userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId',
  headers: {'content-type': 'application/json'},
  body: {
    cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
    clustering: {fields: []},
    creationTime: '',
    defaultCollation: '',
    defaultRoundingMode: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    externalDataConfiguration: {
      autodetect: false,
      avroOptions: {useAvroLogicalTypes: false},
      bigtableOptions: {
        columnFamilies: [
          {
            columns: [
              {
                encoding: '',
                fieldName: '',
                onlyReadLatest: false,
                qualifierEncoded: '',
                qualifierString: '',
                type: ''
              }
            ],
            encoding: '',
            familyId: '',
            onlyReadLatest: false,
            type: ''
          }
        ],
        ignoreUnspecifiedColumnFamilies: false,
        readRowkeyAsString: false
      },
      compression: '',
      connectionId: '',
      csvOptions: {
        allowJaggedRows: false,
        allowQuotedNewlines: false,
        encoding: '',
        fieldDelimiter: '',
        null_marker: '',
        preserveAsciiControlCharacters: false,
        quote: '',
        skipLeadingRows: ''
      },
      decimalTargetTypes: [],
      googleSheetsOptions: {range: '', skipLeadingRows: ''},
      hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
      ignoreUnknownValues: false,
      maxBadRecords: 0,
      metadataCacheMode: '',
      objectMetadata: '',
      parquetOptions: {enableListInference: false, enumAsString: false},
      referenceFileSchemaUri: '',
      schema: {
        fields: [
          {
            categories: {names: []},
            collation: '',
            defaultValueExpression: '',
            description: '',
            fields: [],
            maxLength: '',
            mode: '',
            name: '',
            policyTags: {names: []},
            precision: '',
            roundingMode: '',
            scale: '',
            type: ''
          }
        ]
      },
      sourceFormat: '',
      sourceUris: []
    },
    friendlyName: '',
    id: '',
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    materializedView: {
      allow_non_incremental_definition: false,
      enableRefresh: false,
      lastRefreshTime: '',
      maxStaleness: '',
      query: '',
      refreshIntervalMs: ''
    },
    maxStaleness: '',
    model: {
      modelOptions: {labels: [], lossType: '', modelType: ''},
      trainingRuns: [
        {
          iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
          startTime: '',
          state: '',
          trainingOptions: {
            earlyStop: false,
            l1Reg: '',
            l2Reg: '',
            learnRate: '',
            learnRateStrategy: '',
            lineSearchInitLearnRate: '',
            maxIteration: '',
            minRelProgress: '',
            warmStart: false
          }
        }
      ]
    },
    numBytes: '',
    numLongTermBytes: '',
    numPhysicalBytes: '',
    numRows: '',
    num_active_logical_bytes: '',
    num_active_physical_bytes: '',
    num_long_term_logical_bytes: '',
    num_long_term_physical_bytes: '',
    num_partitions: '',
    num_time_travel_physical_bytes: '',
    num_total_logical_bytes: '',
    num_total_physical_bytes: '',
    rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
    requirePartitionFilter: false,
    schema: {},
    selfLink: '',
    snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
    streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
    tableReference: {},
    timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
    type: '',
    view: {
      query: '',
      useExplicitColumnNames: false,
      useLegacySql: false,
      userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
    }
  },
  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}}/projects/:projectId/datasets/:datasetId/tables/:tableId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  cloneDefinition: {
    baseTableReference: {
      datasetId: '',
      projectId: '',
      tableId: ''
    },
    cloneTime: ''
  },
  clustering: {
    fields: []
  },
  creationTime: '',
  defaultCollation: '',
  defaultRoundingMode: '',
  description: '',
  encryptionConfiguration: {
    kmsKeyName: ''
  },
  etag: '',
  expirationTime: '',
  externalDataConfiguration: {
    autodetect: false,
    avroOptions: {
      useAvroLogicalTypes: false
    },
    bigtableOptions: {
      columnFamilies: [
        {
          columns: [
            {
              encoding: '',
              fieldName: '',
              onlyReadLatest: false,
              qualifierEncoded: '',
              qualifierString: '',
              type: ''
            }
          ],
          encoding: '',
          familyId: '',
          onlyReadLatest: false,
          type: ''
        }
      ],
      ignoreUnspecifiedColumnFamilies: false,
      readRowkeyAsString: false
    },
    compression: '',
    connectionId: '',
    csvOptions: {
      allowJaggedRows: false,
      allowQuotedNewlines: false,
      encoding: '',
      fieldDelimiter: '',
      null_marker: '',
      preserveAsciiControlCharacters: false,
      quote: '',
      skipLeadingRows: ''
    },
    decimalTargetTypes: [],
    googleSheetsOptions: {
      range: '',
      skipLeadingRows: ''
    },
    hivePartitioningOptions: {
      mode: '',
      requirePartitionFilter: false,
      sourceUriPrefix: ''
    },
    ignoreUnknownValues: false,
    maxBadRecords: 0,
    metadataCacheMode: '',
    objectMetadata: '',
    parquetOptions: {
      enableListInference: false,
      enumAsString: false
    },
    referenceFileSchemaUri: '',
    schema: {
      fields: [
        {
          categories: {
            names: []
          },
          collation: '',
          defaultValueExpression: '',
          description: '',
          fields: [],
          maxLength: '',
          mode: '',
          name: '',
          policyTags: {
            names: []
          },
          precision: '',
          roundingMode: '',
          scale: '',
          type: ''
        }
      ]
    },
    sourceFormat: '',
    sourceUris: []
  },
  friendlyName: '',
  id: '',
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  materializedView: {
    allow_non_incremental_definition: false,
    enableRefresh: false,
    lastRefreshTime: '',
    maxStaleness: '',
    query: '',
    refreshIntervalMs: ''
  },
  maxStaleness: '',
  model: {
    modelOptions: {
      labels: [],
      lossType: '',
      modelType: ''
    },
    trainingRuns: [
      {
        iterationResults: [
          {
            durationMs: '',
            evalLoss: '',
            index: 0,
            learnRate: '',
            trainingLoss: ''
          }
        ],
        startTime: '',
        state: '',
        trainingOptions: {
          earlyStop: false,
          l1Reg: '',
          l2Reg: '',
          learnRate: '',
          learnRateStrategy: '',
          lineSearchInitLearnRate: '',
          maxIteration: '',
          minRelProgress: '',
          warmStart: false
        }
      }
    ]
  },
  numBytes: '',
  numLongTermBytes: '',
  numPhysicalBytes: '',
  numRows: '',
  num_active_logical_bytes: '',
  num_active_physical_bytes: '',
  num_long_term_logical_bytes: '',
  num_long_term_physical_bytes: '',
  num_partitions: '',
  num_time_travel_physical_bytes: '',
  num_total_logical_bytes: '',
  num_total_physical_bytes: '',
  rangePartitioning: {
    field: '',
    range: {
      end: '',
      interval: '',
      start: ''
    }
  },
  requirePartitionFilter: false,
  schema: {},
  selfLink: '',
  snapshotDefinition: {
    baseTableReference: {},
    snapshotTime: ''
  },
  streamingBuffer: {
    estimatedBytes: '',
    estimatedRows: '',
    oldestEntryTime: ''
  },
  tableReference: {},
  timePartitioning: {
    expirationMs: '',
    field: '',
    requirePartitionFilter: false,
    type: ''
  },
  type: '',
  view: {
    query: '',
    useExplicitColumnNames: false,
    useLegacySql: false,
    userDefinedFunctionResources: [
      {
        inlineCode: '',
        resourceUri: ''
      }
    ]
  }
});

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}}/projects/:projectId/datasets/:datasetId/tables/:tableId',
  headers: {'content-type': 'application/json'},
  data: {
    cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
    clustering: {fields: []},
    creationTime: '',
    defaultCollation: '',
    defaultRoundingMode: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    externalDataConfiguration: {
      autodetect: false,
      avroOptions: {useAvroLogicalTypes: false},
      bigtableOptions: {
        columnFamilies: [
          {
            columns: [
              {
                encoding: '',
                fieldName: '',
                onlyReadLatest: false,
                qualifierEncoded: '',
                qualifierString: '',
                type: ''
              }
            ],
            encoding: '',
            familyId: '',
            onlyReadLatest: false,
            type: ''
          }
        ],
        ignoreUnspecifiedColumnFamilies: false,
        readRowkeyAsString: false
      },
      compression: '',
      connectionId: '',
      csvOptions: {
        allowJaggedRows: false,
        allowQuotedNewlines: false,
        encoding: '',
        fieldDelimiter: '',
        null_marker: '',
        preserveAsciiControlCharacters: false,
        quote: '',
        skipLeadingRows: ''
      },
      decimalTargetTypes: [],
      googleSheetsOptions: {range: '', skipLeadingRows: ''},
      hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
      ignoreUnknownValues: false,
      maxBadRecords: 0,
      metadataCacheMode: '',
      objectMetadata: '',
      parquetOptions: {enableListInference: false, enumAsString: false},
      referenceFileSchemaUri: '',
      schema: {
        fields: [
          {
            categories: {names: []},
            collation: '',
            defaultValueExpression: '',
            description: '',
            fields: [],
            maxLength: '',
            mode: '',
            name: '',
            policyTags: {names: []},
            precision: '',
            roundingMode: '',
            scale: '',
            type: ''
          }
        ]
      },
      sourceFormat: '',
      sourceUris: []
    },
    friendlyName: '',
    id: '',
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    materializedView: {
      allow_non_incremental_definition: false,
      enableRefresh: false,
      lastRefreshTime: '',
      maxStaleness: '',
      query: '',
      refreshIntervalMs: ''
    },
    maxStaleness: '',
    model: {
      modelOptions: {labels: [], lossType: '', modelType: ''},
      trainingRuns: [
        {
          iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
          startTime: '',
          state: '',
          trainingOptions: {
            earlyStop: false,
            l1Reg: '',
            l2Reg: '',
            learnRate: '',
            learnRateStrategy: '',
            lineSearchInitLearnRate: '',
            maxIteration: '',
            minRelProgress: '',
            warmStart: false
          }
        }
      ]
    },
    numBytes: '',
    numLongTermBytes: '',
    numPhysicalBytes: '',
    numRows: '',
    num_active_logical_bytes: '',
    num_active_physical_bytes: '',
    num_long_term_logical_bytes: '',
    num_long_term_physical_bytes: '',
    num_partitions: '',
    num_time_travel_physical_bytes: '',
    num_total_logical_bytes: '',
    num_total_physical_bytes: '',
    rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
    requirePartitionFilter: false,
    schema: {},
    selfLink: '',
    snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
    streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
    tableReference: {},
    timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
    type: '',
    view: {
      query: '',
      useExplicitColumnNames: false,
      useLegacySql: false,
      userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"cloneDefinition":{"baseTableReference":{"datasetId":"","projectId":"","tableId":""},"cloneTime":""},"clustering":{"fields":[]},"creationTime":"","defaultCollation":"","defaultRoundingMode":"","description":"","encryptionConfiguration":{"kmsKeyName":""},"etag":"","expirationTime":"","externalDataConfiguration":{"autodetect":false,"avroOptions":{"useAvroLogicalTypes":false},"bigtableOptions":{"columnFamilies":[{"columns":[{"encoding":"","fieldName":"","onlyReadLatest":false,"qualifierEncoded":"","qualifierString":"","type":""}],"encoding":"","familyId":"","onlyReadLatest":false,"type":""}],"ignoreUnspecifiedColumnFamilies":false,"readRowkeyAsString":false},"compression":"","connectionId":"","csvOptions":{"allowJaggedRows":false,"allowQuotedNewlines":false,"encoding":"","fieldDelimiter":"","null_marker":"","preserveAsciiControlCharacters":false,"quote":"","skipLeadingRows":""},"decimalTargetTypes":[],"googleSheetsOptions":{"range":"","skipLeadingRows":""},"hivePartitioningOptions":{"mode":"","requirePartitionFilter":false,"sourceUriPrefix":""},"ignoreUnknownValues":false,"maxBadRecords":0,"metadataCacheMode":"","objectMetadata":"","parquetOptions":{"enableListInference":false,"enumAsString":false},"referenceFileSchemaUri":"","schema":{"fields":[{"categories":{"names":[]},"collation":"","defaultValueExpression":"","description":"","fields":[],"maxLength":"","mode":"","name":"","policyTags":{"names":[]},"precision":"","roundingMode":"","scale":"","type":""}]},"sourceFormat":"","sourceUris":[]},"friendlyName":"","id":"","kind":"","labels":{},"lastModifiedTime":"","location":"","materializedView":{"allow_non_incremental_definition":false,"enableRefresh":false,"lastRefreshTime":"","maxStaleness":"","query":"","refreshIntervalMs":""},"maxStaleness":"","model":{"modelOptions":{"labels":[],"lossType":"","modelType":""},"trainingRuns":[{"iterationResults":[{"durationMs":"","evalLoss":"","index":0,"learnRate":"","trainingLoss":""}],"startTime":"","state":"","trainingOptions":{"earlyStop":false,"l1Reg":"","l2Reg":"","learnRate":"","learnRateStrategy":"","lineSearchInitLearnRate":"","maxIteration":"","minRelProgress":"","warmStart":false}}]},"numBytes":"","numLongTermBytes":"","numPhysicalBytes":"","numRows":"","num_active_logical_bytes":"","num_active_physical_bytes":"","num_long_term_logical_bytes":"","num_long_term_physical_bytes":"","num_partitions":"","num_time_travel_physical_bytes":"","num_total_logical_bytes":"","num_total_physical_bytes":"","rangePartitioning":{"field":"","range":{"end":"","interval":"","start":""}},"requirePartitionFilter":false,"schema":{},"selfLink":"","snapshotDefinition":{"baseTableReference":{},"snapshotTime":""},"streamingBuffer":{"estimatedBytes":"","estimatedRows":"","oldestEntryTime":""},"tableReference":{},"timePartitioning":{"expirationMs":"","field":"","requirePartitionFilter":false,"type":""},"type":"","view":{"query":"","useExplicitColumnNames":false,"useLegacySql":false,"userDefinedFunctionResources":[{"inlineCode":"","resourceUri":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"cloneDefinition": @{ @"baseTableReference": @{ @"datasetId": @"", @"projectId": @"", @"tableId": @"" }, @"cloneTime": @"" },
                              @"clustering": @{ @"fields": @[  ] },
                              @"creationTime": @"",
                              @"defaultCollation": @"",
                              @"defaultRoundingMode": @"",
                              @"description": @"",
                              @"encryptionConfiguration": @{ @"kmsKeyName": @"" },
                              @"etag": @"",
                              @"expirationTime": @"",
                              @"externalDataConfiguration": @{ @"autodetect": @NO, @"avroOptions": @{ @"useAvroLogicalTypes": @NO }, @"bigtableOptions": @{ @"columnFamilies": @[ @{ @"columns": @[ @{ @"encoding": @"", @"fieldName": @"", @"onlyReadLatest": @NO, @"qualifierEncoded": @"", @"qualifierString": @"", @"type": @"" } ], @"encoding": @"", @"familyId": @"", @"onlyReadLatest": @NO, @"type": @"" } ], @"ignoreUnspecifiedColumnFamilies": @NO, @"readRowkeyAsString": @NO }, @"compression": @"", @"connectionId": @"", @"csvOptions": @{ @"allowJaggedRows": @NO, @"allowQuotedNewlines": @NO, @"encoding": @"", @"fieldDelimiter": @"", @"null_marker": @"", @"preserveAsciiControlCharacters": @NO, @"quote": @"", @"skipLeadingRows": @"" }, @"decimalTargetTypes": @[  ], @"googleSheetsOptions": @{ @"range": @"", @"skipLeadingRows": @"" }, @"hivePartitioningOptions": @{ @"mode": @"", @"requirePartitionFilter": @NO, @"sourceUriPrefix": @"" }, @"ignoreUnknownValues": @NO, @"maxBadRecords": @0, @"metadataCacheMode": @"", @"objectMetadata": @"", @"parquetOptions": @{ @"enableListInference": @NO, @"enumAsString": @NO }, @"referenceFileSchemaUri": @"", @"schema": @{ @"fields": @[ @{ @"categories": @{ @"names": @[  ] }, @"collation": @"", @"defaultValueExpression": @"", @"description": @"", @"fields": @[  ], @"maxLength": @"", @"mode": @"", @"name": @"", @"policyTags": @{ @"names": @[  ] }, @"precision": @"", @"roundingMode": @"", @"scale": @"", @"type": @"" } ] }, @"sourceFormat": @"", @"sourceUris": @[  ] },
                              @"friendlyName": @"",
                              @"id": @"",
                              @"kind": @"",
                              @"labels": @{  },
                              @"lastModifiedTime": @"",
                              @"location": @"",
                              @"materializedView": @{ @"allow_non_incremental_definition": @NO, @"enableRefresh": @NO, @"lastRefreshTime": @"", @"maxStaleness": @"", @"query": @"", @"refreshIntervalMs": @"" },
                              @"maxStaleness": @"",
                              @"model": @{ @"modelOptions": @{ @"labels": @[  ], @"lossType": @"", @"modelType": @"" }, @"trainingRuns": @[ @{ @"iterationResults": @[ @{ @"durationMs": @"", @"evalLoss": @"", @"index": @0, @"learnRate": @"", @"trainingLoss": @"" } ], @"startTime": @"", @"state": @"", @"trainingOptions": @{ @"earlyStop": @NO, @"l1Reg": @"", @"l2Reg": @"", @"learnRate": @"", @"learnRateStrategy": @"", @"lineSearchInitLearnRate": @"", @"maxIteration": @"", @"minRelProgress": @"", @"warmStart": @NO } } ] },
                              @"numBytes": @"",
                              @"numLongTermBytes": @"",
                              @"numPhysicalBytes": @"",
                              @"numRows": @"",
                              @"num_active_logical_bytes": @"",
                              @"num_active_physical_bytes": @"",
                              @"num_long_term_logical_bytes": @"",
                              @"num_long_term_physical_bytes": @"",
                              @"num_partitions": @"",
                              @"num_time_travel_physical_bytes": @"",
                              @"num_total_logical_bytes": @"",
                              @"num_total_physical_bytes": @"",
                              @"rangePartitioning": @{ @"field": @"", @"range": @{ @"end": @"", @"interval": @"", @"start": @"" } },
                              @"requirePartitionFilter": @NO,
                              @"schema": @{  },
                              @"selfLink": @"",
                              @"snapshotDefinition": @{ @"baseTableReference": @{  }, @"snapshotTime": @"" },
                              @"streamingBuffer": @{ @"estimatedBytes": @"", @"estimatedRows": @"", @"oldestEntryTime": @"" },
                              @"tableReference": @{  },
                              @"timePartitioning": @{ @"expirationMs": @"", @"field": @"", @"requirePartitionFilter": @NO, @"type": @"" },
                              @"type": @"",
                              @"view": @{ @"query": @"", @"useExplicitColumnNames": @NO, @"useLegacySql": @NO, @"userDefinedFunctionResources": @[ @{ @"inlineCode": @"", @"resourceUri": @"" } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"]
                                                       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}}/projects/:projectId/datasets/:datasetId/tables/:tableId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId",
  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([
    'cloneDefinition' => [
        'baseTableReference' => [
                'datasetId' => '',
                'projectId' => '',
                'tableId' => ''
        ],
        'cloneTime' => ''
    ],
    'clustering' => [
        'fields' => [
                
        ]
    ],
    'creationTime' => '',
    'defaultCollation' => '',
    'defaultRoundingMode' => '',
    'description' => '',
    'encryptionConfiguration' => [
        'kmsKeyName' => ''
    ],
    'etag' => '',
    'expirationTime' => '',
    'externalDataConfiguration' => [
        'autodetect' => null,
        'avroOptions' => [
                'useAvroLogicalTypes' => null
        ],
        'bigtableOptions' => [
                'columnFamilies' => [
                                [
                                                                'columns' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'encoding' => '',
                                                                                                                                                                                                                                                                'fieldName' => '',
                                                                                                                                                                                                                                                                'onlyReadLatest' => null,
                                                                                                                                                                                                                                                                'qualifierEncoded' => '',
                                                                                                                                                                                                                                                                'qualifierString' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'encoding' => '',
                                                                'familyId' => '',
                                                                'onlyReadLatest' => null,
                                                                'type' => ''
                                ]
                ],
                'ignoreUnspecifiedColumnFamilies' => null,
                'readRowkeyAsString' => null
        ],
        'compression' => '',
        'connectionId' => '',
        'csvOptions' => [
                'allowJaggedRows' => null,
                'allowQuotedNewlines' => null,
                'encoding' => '',
                'fieldDelimiter' => '',
                'null_marker' => '',
                'preserveAsciiControlCharacters' => null,
                'quote' => '',
                'skipLeadingRows' => ''
        ],
        'decimalTargetTypes' => [
                
        ],
        'googleSheetsOptions' => [
                'range' => '',
                'skipLeadingRows' => ''
        ],
        'hivePartitioningOptions' => [
                'mode' => '',
                'requirePartitionFilter' => null,
                'sourceUriPrefix' => ''
        ],
        'ignoreUnknownValues' => null,
        'maxBadRecords' => 0,
        'metadataCacheMode' => '',
        'objectMetadata' => '',
        'parquetOptions' => [
                'enableListInference' => null,
                'enumAsString' => null
        ],
        'referenceFileSchemaUri' => '',
        'schema' => [
                'fields' => [
                                [
                                                                'categories' => [
                                                                                                                                'names' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'collation' => '',
                                                                'defaultValueExpression' => '',
                                                                'description' => '',
                                                                'fields' => [
                                                                                                                                
                                                                ],
                                                                'maxLength' => '',
                                                                'mode' => '',
                                                                'name' => '',
                                                                'policyTags' => [
                                                                                                                                'names' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'precision' => '',
                                                                'roundingMode' => '',
                                                                'scale' => '',
                                                                'type' => ''
                                ]
                ]
        ],
        'sourceFormat' => '',
        'sourceUris' => [
                
        ]
    ],
    'friendlyName' => '',
    'id' => '',
    'kind' => '',
    'labels' => [
        
    ],
    'lastModifiedTime' => '',
    'location' => '',
    'materializedView' => [
        'allow_non_incremental_definition' => null,
        'enableRefresh' => null,
        'lastRefreshTime' => '',
        'maxStaleness' => '',
        'query' => '',
        'refreshIntervalMs' => ''
    ],
    'maxStaleness' => '',
    'model' => [
        'modelOptions' => [
                'labels' => [
                                
                ],
                'lossType' => '',
                'modelType' => ''
        ],
        'trainingRuns' => [
                [
                                'iterationResults' => [
                                                                [
                                                                                                                                'durationMs' => '',
                                                                                                                                'evalLoss' => '',
                                                                                                                                'index' => 0,
                                                                                                                                'learnRate' => '',
                                                                                                                                'trainingLoss' => ''
                                                                ]
                                ],
                                'startTime' => '',
                                'state' => '',
                                'trainingOptions' => [
                                                                'earlyStop' => null,
                                                                'l1Reg' => '',
                                                                'l2Reg' => '',
                                                                'learnRate' => '',
                                                                'learnRateStrategy' => '',
                                                                'lineSearchInitLearnRate' => '',
                                                                'maxIteration' => '',
                                                                'minRelProgress' => '',
                                                                'warmStart' => null
                                ]
                ]
        ]
    ],
    'numBytes' => '',
    'numLongTermBytes' => '',
    'numPhysicalBytes' => '',
    'numRows' => '',
    'num_active_logical_bytes' => '',
    'num_active_physical_bytes' => '',
    'num_long_term_logical_bytes' => '',
    'num_long_term_physical_bytes' => '',
    'num_partitions' => '',
    'num_time_travel_physical_bytes' => '',
    'num_total_logical_bytes' => '',
    'num_total_physical_bytes' => '',
    'rangePartitioning' => [
        'field' => '',
        'range' => [
                'end' => '',
                'interval' => '',
                'start' => ''
        ]
    ],
    'requirePartitionFilter' => null,
    'schema' => [
        
    ],
    'selfLink' => '',
    'snapshotDefinition' => [
        'baseTableReference' => [
                
        ],
        'snapshotTime' => ''
    ],
    'streamingBuffer' => [
        'estimatedBytes' => '',
        'estimatedRows' => '',
        'oldestEntryTime' => ''
    ],
    'tableReference' => [
        
    ],
    'timePartitioning' => [
        'expirationMs' => '',
        'field' => '',
        'requirePartitionFilter' => null,
        'type' => ''
    ],
    'type' => '',
    'view' => [
        'query' => '',
        'useExplicitColumnNames' => null,
        'useLegacySql' => null,
        'userDefinedFunctionResources' => [
                [
                                'inlineCode' => '',
                                'resourceUri' => ''
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-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}}/projects/:projectId/datasets/:datasetId/tables/:tableId', [
  'body' => '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cloneDefinition' => [
    'baseTableReference' => [
        'datasetId' => '',
        'projectId' => '',
        'tableId' => ''
    ],
    'cloneTime' => ''
  ],
  'clustering' => [
    'fields' => [
        
    ]
  ],
  'creationTime' => '',
  'defaultCollation' => '',
  'defaultRoundingMode' => '',
  'description' => '',
  'encryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'etag' => '',
  'expirationTime' => '',
  'externalDataConfiguration' => [
    'autodetect' => null,
    'avroOptions' => [
        'useAvroLogicalTypes' => null
    ],
    'bigtableOptions' => [
        'columnFamilies' => [
                [
                                'columns' => [
                                                                [
                                                                                                                                'encoding' => '',
                                                                                                                                'fieldName' => '',
                                                                                                                                'onlyReadLatest' => null,
                                                                                                                                'qualifierEncoded' => '',
                                                                                                                                'qualifierString' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'encoding' => '',
                                'familyId' => '',
                                'onlyReadLatest' => null,
                                'type' => ''
                ]
        ],
        'ignoreUnspecifiedColumnFamilies' => null,
        'readRowkeyAsString' => null
    ],
    'compression' => '',
    'connectionId' => '',
    'csvOptions' => [
        'allowJaggedRows' => null,
        'allowQuotedNewlines' => null,
        'encoding' => '',
        'fieldDelimiter' => '',
        'null_marker' => '',
        'preserveAsciiControlCharacters' => null,
        'quote' => '',
        'skipLeadingRows' => ''
    ],
    'decimalTargetTypes' => [
        
    ],
    'googleSheetsOptions' => [
        'range' => '',
        'skipLeadingRows' => ''
    ],
    'hivePartitioningOptions' => [
        'mode' => '',
        'requirePartitionFilter' => null,
        'sourceUriPrefix' => ''
    ],
    'ignoreUnknownValues' => null,
    'maxBadRecords' => 0,
    'metadataCacheMode' => '',
    'objectMetadata' => '',
    'parquetOptions' => [
        'enableListInference' => null,
        'enumAsString' => null
    ],
    'referenceFileSchemaUri' => '',
    'schema' => [
        'fields' => [
                [
                                'categories' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'collation' => '',
                                'defaultValueExpression' => '',
                                'description' => '',
                                'fields' => [
                                                                
                                ],
                                'maxLength' => '',
                                'mode' => '',
                                'name' => '',
                                'policyTags' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'precision' => '',
                                'roundingMode' => '',
                                'scale' => '',
                                'type' => ''
                ]
        ]
    ],
    'sourceFormat' => '',
    'sourceUris' => [
        
    ]
  ],
  'friendlyName' => '',
  'id' => '',
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'materializedView' => [
    'allow_non_incremental_definition' => null,
    'enableRefresh' => null,
    'lastRefreshTime' => '',
    'maxStaleness' => '',
    'query' => '',
    'refreshIntervalMs' => ''
  ],
  'maxStaleness' => '',
  'model' => [
    'modelOptions' => [
        'labels' => [
                
        ],
        'lossType' => '',
        'modelType' => ''
    ],
    'trainingRuns' => [
        [
                'iterationResults' => [
                                [
                                                                'durationMs' => '',
                                                                'evalLoss' => '',
                                                                'index' => 0,
                                                                'learnRate' => '',
                                                                'trainingLoss' => ''
                                ]
                ],
                'startTime' => '',
                'state' => '',
                'trainingOptions' => [
                                'earlyStop' => null,
                                'l1Reg' => '',
                                'l2Reg' => '',
                                'learnRate' => '',
                                'learnRateStrategy' => '',
                                'lineSearchInitLearnRate' => '',
                                'maxIteration' => '',
                                'minRelProgress' => '',
                                'warmStart' => null
                ]
        ]
    ]
  ],
  'numBytes' => '',
  'numLongTermBytes' => '',
  'numPhysicalBytes' => '',
  'numRows' => '',
  'num_active_logical_bytes' => '',
  'num_active_physical_bytes' => '',
  'num_long_term_logical_bytes' => '',
  'num_long_term_physical_bytes' => '',
  'num_partitions' => '',
  'num_time_travel_physical_bytes' => '',
  'num_total_logical_bytes' => '',
  'num_total_physical_bytes' => '',
  'rangePartitioning' => [
    'field' => '',
    'range' => [
        'end' => '',
        'interval' => '',
        'start' => ''
    ]
  ],
  'requirePartitionFilter' => null,
  'schema' => [
    
  ],
  'selfLink' => '',
  'snapshotDefinition' => [
    'baseTableReference' => [
        
    ],
    'snapshotTime' => ''
  ],
  'streamingBuffer' => [
    'estimatedBytes' => '',
    'estimatedRows' => '',
    'oldestEntryTime' => ''
  ],
  'tableReference' => [
    
  ],
  'timePartitioning' => [
    'expirationMs' => '',
    'field' => '',
    'requirePartitionFilter' => null,
    'type' => ''
  ],
  'type' => '',
  'view' => [
    'query' => '',
    'useExplicitColumnNames' => null,
    'useLegacySql' => null,
    'userDefinedFunctionResources' => [
        [
                'inlineCode' => '',
                'resourceUri' => ''
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cloneDefinition' => [
    'baseTableReference' => [
        'datasetId' => '',
        'projectId' => '',
        'tableId' => ''
    ],
    'cloneTime' => ''
  ],
  'clustering' => [
    'fields' => [
        
    ]
  ],
  'creationTime' => '',
  'defaultCollation' => '',
  'defaultRoundingMode' => '',
  'description' => '',
  'encryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'etag' => '',
  'expirationTime' => '',
  'externalDataConfiguration' => [
    'autodetect' => null,
    'avroOptions' => [
        'useAvroLogicalTypes' => null
    ],
    'bigtableOptions' => [
        'columnFamilies' => [
                [
                                'columns' => [
                                                                [
                                                                                                                                'encoding' => '',
                                                                                                                                'fieldName' => '',
                                                                                                                                'onlyReadLatest' => null,
                                                                                                                                'qualifierEncoded' => '',
                                                                                                                                'qualifierString' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'encoding' => '',
                                'familyId' => '',
                                'onlyReadLatest' => null,
                                'type' => ''
                ]
        ],
        'ignoreUnspecifiedColumnFamilies' => null,
        'readRowkeyAsString' => null
    ],
    'compression' => '',
    'connectionId' => '',
    'csvOptions' => [
        'allowJaggedRows' => null,
        'allowQuotedNewlines' => null,
        'encoding' => '',
        'fieldDelimiter' => '',
        'null_marker' => '',
        'preserveAsciiControlCharacters' => null,
        'quote' => '',
        'skipLeadingRows' => ''
    ],
    'decimalTargetTypes' => [
        
    ],
    'googleSheetsOptions' => [
        'range' => '',
        'skipLeadingRows' => ''
    ],
    'hivePartitioningOptions' => [
        'mode' => '',
        'requirePartitionFilter' => null,
        'sourceUriPrefix' => ''
    ],
    'ignoreUnknownValues' => null,
    'maxBadRecords' => 0,
    'metadataCacheMode' => '',
    'objectMetadata' => '',
    'parquetOptions' => [
        'enableListInference' => null,
        'enumAsString' => null
    ],
    'referenceFileSchemaUri' => '',
    'schema' => [
        'fields' => [
                [
                                'categories' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'collation' => '',
                                'defaultValueExpression' => '',
                                'description' => '',
                                'fields' => [
                                                                
                                ],
                                'maxLength' => '',
                                'mode' => '',
                                'name' => '',
                                'policyTags' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'precision' => '',
                                'roundingMode' => '',
                                'scale' => '',
                                'type' => ''
                ]
        ]
    ],
    'sourceFormat' => '',
    'sourceUris' => [
        
    ]
  ],
  'friendlyName' => '',
  'id' => '',
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'materializedView' => [
    'allow_non_incremental_definition' => null,
    'enableRefresh' => null,
    'lastRefreshTime' => '',
    'maxStaleness' => '',
    'query' => '',
    'refreshIntervalMs' => ''
  ],
  'maxStaleness' => '',
  'model' => [
    'modelOptions' => [
        'labels' => [
                
        ],
        'lossType' => '',
        'modelType' => ''
    ],
    'trainingRuns' => [
        [
                'iterationResults' => [
                                [
                                                                'durationMs' => '',
                                                                'evalLoss' => '',
                                                                'index' => 0,
                                                                'learnRate' => '',
                                                                'trainingLoss' => ''
                                ]
                ],
                'startTime' => '',
                'state' => '',
                'trainingOptions' => [
                                'earlyStop' => null,
                                'l1Reg' => '',
                                'l2Reg' => '',
                                'learnRate' => '',
                                'learnRateStrategy' => '',
                                'lineSearchInitLearnRate' => '',
                                'maxIteration' => '',
                                'minRelProgress' => '',
                                'warmStart' => null
                ]
        ]
    ]
  ],
  'numBytes' => '',
  'numLongTermBytes' => '',
  'numPhysicalBytes' => '',
  'numRows' => '',
  'num_active_logical_bytes' => '',
  'num_active_physical_bytes' => '',
  'num_long_term_logical_bytes' => '',
  'num_long_term_physical_bytes' => '',
  'num_partitions' => '',
  'num_time_travel_physical_bytes' => '',
  'num_total_logical_bytes' => '',
  'num_total_physical_bytes' => '',
  'rangePartitioning' => [
    'field' => '',
    'range' => [
        'end' => '',
        'interval' => '',
        'start' => ''
    ]
  ],
  'requirePartitionFilter' => null,
  'schema' => [
    
  ],
  'selfLink' => '',
  'snapshotDefinition' => [
    'baseTableReference' => [
        
    ],
    'snapshotTime' => ''
  ],
  'streamingBuffer' => [
    'estimatedBytes' => '',
    'estimatedRows' => '',
    'oldestEntryTime' => ''
  ],
  'tableReference' => [
    
  ],
  'timePartitioning' => [
    'expirationMs' => '',
    'field' => '',
    'requirePartitionFilter' => null,
    'type' => ''
  ],
  'type' => '',
  'view' => [
    'query' => '',
    'useExplicitColumnNames' => null,
    'useLegacySql' => null,
    'userDefinedFunctionResources' => [
        [
                'inlineCode' => '',
                'resourceUri' => ''
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');
$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}}/projects/:projectId/datasets/:datasetId/tables/:tableId' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PATCH", "/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

payload = {
    "cloneDefinition": {
        "baseTableReference": {
            "datasetId": "",
            "projectId": "",
            "tableId": ""
        },
        "cloneTime": ""
    },
    "clustering": { "fields": [] },
    "creationTime": "",
    "defaultCollation": "",
    "defaultRoundingMode": "",
    "description": "",
    "encryptionConfiguration": { "kmsKeyName": "" },
    "etag": "",
    "expirationTime": "",
    "externalDataConfiguration": {
        "autodetect": False,
        "avroOptions": { "useAvroLogicalTypes": False },
        "bigtableOptions": {
            "columnFamilies": [
                {
                    "columns": [
                        {
                            "encoding": "",
                            "fieldName": "",
                            "onlyReadLatest": False,
                            "qualifierEncoded": "",
                            "qualifierString": "",
                            "type": ""
                        }
                    ],
                    "encoding": "",
                    "familyId": "",
                    "onlyReadLatest": False,
                    "type": ""
                }
            ],
            "ignoreUnspecifiedColumnFamilies": False,
            "readRowkeyAsString": False
        },
        "compression": "",
        "connectionId": "",
        "csvOptions": {
            "allowJaggedRows": False,
            "allowQuotedNewlines": False,
            "encoding": "",
            "fieldDelimiter": "",
            "null_marker": "",
            "preserveAsciiControlCharacters": False,
            "quote": "",
            "skipLeadingRows": ""
        },
        "decimalTargetTypes": [],
        "googleSheetsOptions": {
            "range": "",
            "skipLeadingRows": ""
        },
        "hivePartitioningOptions": {
            "mode": "",
            "requirePartitionFilter": False,
            "sourceUriPrefix": ""
        },
        "ignoreUnknownValues": False,
        "maxBadRecords": 0,
        "metadataCacheMode": "",
        "objectMetadata": "",
        "parquetOptions": {
            "enableListInference": False,
            "enumAsString": False
        },
        "referenceFileSchemaUri": "",
        "schema": { "fields": [
                {
                    "categories": { "names": [] },
                    "collation": "",
                    "defaultValueExpression": "",
                    "description": "",
                    "fields": [],
                    "maxLength": "",
                    "mode": "",
                    "name": "",
                    "policyTags": { "names": [] },
                    "precision": "",
                    "roundingMode": "",
                    "scale": "",
                    "type": ""
                }
            ] },
        "sourceFormat": "",
        "sourceUris": []
    },
    "friendlyName": "",
    "id": "",
    "kind": "",
    "labels": {},
    "lastModifiedTime": "",
    "location": "",
    "materializedView": {
        "allow_non_incremental_definition": False,
        "enableRefresh": False,
        "lastRefreshTime": "",
        "maxStaleness": "",
        "query": "",
        "refreshIntervalMs": ""
    },
    "maxStaleness": "",
    "model": {
        "modelOptions": {
            "labels": [],
            "lossType": "",
            "modelType": ""
        },
        "trainingRuns": [
            {
                "iterationResults": [
                    {
                        "durationMs": "",
                        "evalLoss": "",
                        "index": 0,
                        "learnRate": "",
                        "trainingLoss": ""
                    }
                ],
                "startTime": "",
                "state": "",
                "trainingOptions": {
                    "earlyStop": False,
                    "l1Reg": "",
                    "l2Reg": "",
                    "learnRate": "",
                    "learnRateStrategy": "",
                    "lineSearchInitLearnRate": "",
                    "maxIteration": "",
                    "minRelProgress": "",
                    "warmStart": False
                }
            }
        ]
    },
    "numBytes": "",
    "numLongTermBytes": "",
    "numPhysicalBytes": "",
    "numRows": "",
    "num_active_logical_bytes": "",
    "num_active_physical_bytes": "",
    "num_long_term_logical_bytes": "",
    "num_long_term_physical_bytes": "",
    "num_partitions": "",
    "num_time_travel_physical_bytes": "",
    "num_total_logical_bytes": "",
    "num_total_physical_bytes": "",
    "rangePartitioning": {
        "field": "",
        "range": {
            "end": "",
            "interval": "",
            "start": ""
        }
    },
    "requirePartitionFilter": False,
    "schema": {},
    "selfLink": "",
    "snapshotDefinition": {
        "baseTableReference": {},
        "snapshotTime": ""
    },
    "streamingBuffer": {
        "estimatedBytes": "",
        "estimatedRows": "",
        "oldestEntryTime": ""
    },
    "tableReference": {},
    "timePartitioning": {
        "expirationMs": "",
        "field": "",
        "requirePartitionFilter": False,
        "type": ""
    },
    "type": "",
    "view": {
        "query": "",
        "useExplicitColumnNames": False,
        "useLegacySql": False,
        "userDefinedFunctionResources": [
            {
                "inlineCode": "",
                "resourceUri": ""
            }
        ]
    }
}
headers = {"content-type": "application/json"}

response = requests.patch(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

payload <- "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\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}}/projects/:projectId/datasets/:datasetId/tables/:tableId")

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  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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.patch('/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId') do |req|
  req.body = "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId";

    let payload = json!({
        "cloneDefinition": json!({
            "baseTableReference": json!({
                "datasetId": "",
                "projectId": "",
                "tableId": ""
            }),
            "cloneTime": ""
        }),
        "clustering": json!({"fields": ()}),
        "creationTime": "",
        "defaultCollation": "",
        "defaultRoundingMode": "",
        "description": "",
        "encryptionConfiguration": json!({"kmsKeyName": ""}),
        "etag": "",
        "expirationTime": "",
        "externalDataConfiguration": json!({
            "autodetect": false,
            "avroOptions": json!({"useAvroLogicalTypes": false}),
            "bigtableOptions": json!({
                "columnFamilies": (
                    json!({
                        "columns": (
                            json!({
                                "encoding": "",
                                "fieldName": "",
                                "onlyReadLatest": false,
                                "qualifierEncoded": "",
                                "qualifierString": "",
                                "type": ""
                            })
                        ),
                        "encoding": "",
                        "familyId": "",
                        "onlyReadLatest": false,
                        "type": ""
                    })
                ),
                "ignoreUnspecifiedColumnFamilies": false,
                "readRowkeyAsString": false
            }),
            "compression": "",
            "connectionId": "",
            "csvOptions": json!({
                "allowJaggedRows": false,
                "allowQuotedNewlines": false,
                "encoding": "",
                "fieldDelimiter": "",
                "null_marker": "",
                "preserveAsciiControlCharacters": false,
                "quote": "",
                "skipLeadingRows": ""
            }),
            "decimalTargetTypes": (),
            "googleSheetsOptions": json!({
                "range": "",
                "skipLeadingRows": ""
            }),
            "hivePartitioningOptions": json!({
                "mode": "",
                "requirePartitionFilter": false,
                "sourceUriPrefix": ""
            }),
            "ignoreUnknownValues": false,
            "maxBadRecords": 0,
            "metadataCacheMode": "",
            "objectMetadata": "",
            "parquetOptions": json!({
                "enableListInference": false,
                "enumAsString": false
            }),
            "referenceFileSchemaUri": "",
            "schema": json!({"fields": (
                    json!({
                        "categories": json!({"names": ()}),
                        "collation": "",
                        "defaultValueExpression": "",
                        "description": "",
                        "fields": (),
                        "maxLength": "",
                        "mode": "",
                        "name": "",
                        "policyTags": json!({"names": ()}),
                        "precision": "",
                        "roundingMode": "",
                        "scale": "",
                        "type": ""
                    })
                )}),
            "sourceFormat": "",
            "sourceUris": ()
        }),
        "friendlyName": "",
        "id": "",
        "kind": "",
        "labels": json!({}),
        "lastModifiedTime": "",
        "location": "",
        "materializedView": json!({
            "allow_non_incremental_definition": false,
            "enableRefresh": false,
            "lastRefreshTime": "",
            "maxStaleness": "",
            "query": "",
            "refreshIntervalMs": ""
        }),
        "maxStaleness": "",
        "model": json!({
            "modelOptions": json!({
                "labels": (),
                "lossType": "",
                "modelType": ""
            }),
            "trainingRuns": (
                json!({
                    "iterationResults": (
                        json!({
                            "durationMs": "",
                            "evalLoss": "",
                            "index": 0,
                            "learnRate": "",
                            "trainingLoss": ""
                        })
                    ),
                    "startTime": "",
                    "state": "",
                    "trainingOptions": json!({
                        "earlyStop": false,
                        "l1Reg": "",
                        "l2Reg": "",
                        "learnRate": "",
                        "learnRateStrategy": "",
                        "lineSearchInitLearnRate": "",
                        "maxIteration": "",
                        "minRelProgress": "",
                        "warmStart": false
                    })
                })
            )
        }),
        "numBytes": "",
        "numLongTermBytes": "",
        "numPhysicalBytes": "",
        "numRows": "",
        "num_active_logical_bytes": "",
        "num_active_physical_bytes": "",
        "num_long_term_logical_bytes": "",
        "num_long_term_physical_bytes": "",
        "num_partitions": "",
        "num_time_travel_physical_bytes": "",
        "num_total_logical_bytes": "",
        "num_total_physical_bytes": "",
        "rangePartitioning": json!({
            "field": "",
            "range": json!({
                "end": "",
                "interval": "",
                "start": ""
            })
        }),
        "requirePartitionFilter": false,
        "schema": json!({}),
        "selfLink": "",
        "snapshotDefinition": json!({
            "baseTableReference": json!({}),
            "snapshotTime": ""
        }),
        "streamingBuffer": json!({
            "estimatedBytes": "",
            "estimatedRows": "",
            "oldestEntryTime": ""
        }),
        "tableReference": json!({}),
        "timePartitioning": json!({
            "expirationMs": "",
            "field": "",
            "requirePartitionFilter": false,
            "type": ""
        }),
        "type": "",
        "view": json!({
            "query": "",
            "useExplicitColumnNames": false,
            "useLegacySql": false,
            "userDefinedFunctionResources": (
                json!({
                    "inlineCode": "",
                    "resourceUri": ""
                })
            )
        })
    });

    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}}/projects/:projectId/datasets/:datasetId/tables/:tableId \
  --header 'content-type: application/json' \
  --data '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}'
echo '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}' |  \
  http PATCH {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'content-type: application/json' \
  --body-data '{\n  "cloneDefinition": {\n    "baseTableReference": {\n      "datasetId": "",\n      "projectId": "",\n      "tableId": ""\n    },\n    "cloneTime": ""\n  },\n  "clustering": {\n    "fields": []\n  },\n  "creationTime": "",\n  "defaultCollation": "",\n  "defaultRoundingMode": "",\n  "description": "",\n  "encryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "etag": "",\n  "expirationTime": "",\n  "externalDataConfiguration": {\n    "autodetect": false,\n    "avroOptions": {\n      "useAvroLogicalTypes": false\n    },\n    "bigtableOptions": {\n      "columnFamilies": [\n        {\n          "columns": [\n            {\n              "encoding": "",\n              "fieldName": "",\n              "onlyReadLatest": false,\n              "qualifierEncoded": "",\n              "qualifierString": "",\n              "type": ""\n            }\n          ],\n          "encoding": "",\n          "familyId": "",\n          "onlyReadLatest": false,\n          "type": ""\n        }\n      ],\n      "ignoreUnspecifiedColumnFamilies": false,\n      "readRowkeyAsString": false\n    },\n    "compression": "",\n    "connectionId": "",\n    "csvOptions": {\n      "allowJaggedRows": false,\n      "allowQuotedNewlines": false,\n      "encoding": "",\n      "fieldDelimiter": "",\n      "null_marker": "",\n      "preserveAsciiControlCharacters": false,\n      "quote": "",\n      "skipLeadingRows": ""\n    },\n    "decimalTargetTypes": [],\n    "googleSheetsOptions": {\n      "range": "",\n      "skipLeadingRows": ""\n    },\n    "hivePartitioningOptions": {\n      "mode": "",\n      "requirePartitionFilter": false,\n      "sourceUriPrefix": ""\n    },\n    "ignoreUnknownValues": false,\n    "maxBadRecords": 0,\n    "metadataCacheMode": "",\n    "objectMetadata": "",\n    "parquetOptions": {\n      "enableListInference": false,\n      "enumAsString": false\n    },\n    "referenceFileSchemaUri": "",\n    "schema": {\n      "fields": [\n        {\n          "categories": {\n            "names": []\n          },\n          "collation": "",\n          "defaultValueExpression": "",\n          "description": "",\n          "fields": [],\n          "maxLength": "",\n          "mode": "",\n          "name": "",\n          "policyTags": {\n            "names": []\n          },\n          "precision": "",\n          "roundingMode": "",\n          "scale": "",\n          "type": ""\n        }\n      ]\n    },\n    "sourceFormat": "",\n    "sourceUris": []\n  },\n  "friendlyName": "",\n  "id": "",\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "materializedView": {\n    "allow_non_incremental_definition": false,\n    "enableRefresh": false,\n    "lastRefreshTime": "",\n    "maxStaleness": "",\n    "query": "",\n    "refreshIntervalMs": ""\n  },\n  "maxStaleness": "",\n  "model": {\n    "modelOptions": {\n      "labels": [],\n      "lossType": "",\n      "modelType": ""\n    },\n    "trainingRuns": [\n      {\n        "iterationResults": [\n          {\n            "durationMs": "",\n            "evalLoss": "",\n            "index": 0,\n            "learnRate": "",\n            "trainingLoss": ""\n          }\n        ],\n        "startTime": "",\n        "state": "",\n        "trainingOptions": {\n          "earlyStop": false,\n          "l1Reg": "",\n          "l2Reg": "",\n          "learnRate": "",\n          "learnRateStrategy": "",\n          "lineSearchInitLearnRate": "",\n          "maxIteration": "",\n          "minRelProgress": "",\n          "warmStart": false\n        }\n      }\n    ]\n  },\n  "numBytes": "",\n  "numLongTermBytes": "",\n  "numPhysicalBytes": "",\n  "numRows": "",\n  "num_active_logical_bytes": "",\n  "num_active_physical_bytes": "",\n  "num_long_term_logical_bytes": "",\n  "num_long_term_physical_bytes": "",\n  "num_partitions": "",\n  "num_time_travel_physical_bytes": "",\n  "num_total_logical_bytes": "",\n  "num_total_physical_bytes": "",\n  "rangePartitioning": {\n    "field": "",\n    "range": {\n      "end": "",\n      "interval": "",\n      "start": ""\n    }\n  },\n  "requirePartitionFilter": false,\n  "schema": {},\n  "selfLink": "",\n  "snapshotDefinition": {\n    "baseTableReference": {},\n    "snapshotTime": ""\n  },\n  "streamingBuffer": {\n    "estimatedBytes": "",\n    "estimatedRows": "",\n    "oldestEntryTime": ""\n  },\n  "tableReference": {},\n  "timePartitioning": {\n    "expirationMs": "",\n    "field": "",\n    "requirePartitionFilter": false,\n    "type": ""\n  },\n  "type": "",\n  "view": {\n    "query": "",\n    "useExplicitColumnNames": false,\n    "useLegacySql": false,\n    "userDefinedFunctionResources": [\n      {\n        "inlineCode": "",\n        "resourceUri": ""\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "cloneDefinition": [
    "baseTableReference": [
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    ],
    "cloneTime": ""
  ],
  "clustering": ["fields": []],
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": ["kmsKeyName": ""],
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": [
    "autodetect": false,
    "avroOptions": ["useAvroLogicalTypes": false],
    "bigtableOptions": [
      "columnFamilies": [
        [
          "columns": [
            [
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            ]
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        ]
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    ],
    "compression": "",
    "connectionId": "",
    "csvOptions": [
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    ],
    "decimalTargetTypes": [],
    "googleSheetsOptions": [
      "range": "",
      "skipLeadingRows": ""
    ],
    "hivePartitioningOptions": [
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    ],
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": [
      "enableListInference": false,
      "enumAsString": false
    ],
    "referenceFileSchemaUri": "",
    "schema": ["fields": [
        [
          "categories": ["names": []],
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": ["names": []],
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        ]
      ]],
    "sourceFormat": "",
    "sourceUris": []
  ],
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": [],
  "lastModifiedTime": "",
  "location": "",
  "materializedView": [
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  ],
  "maxStaleness": "",
  "model": [
    "modelOptions": [
      "labels": [],
      "lossType": "",
      "modelType": ""
    ],
    "trainingRuns": [
      [
        "iterationResults": [
          [
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          ]
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": [
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        ]
      ]
    ]
  ],
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": [
    "field": "",
    "range": [
      "end": "",
      "interval": "",
      "start": ""
    ]
  ],
  "requirePartitionFilter": false,
  "schema": [],
  "selfLink": "",
  "snapshotDefinition": [
    "baseTableReference": [],
    "snapshotTime": ""
  ],
  "streamingBuffer": [
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  ],
  "tableReference": [],
  "timePartitioning": [
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  ],
  "type": "",
  "view": [
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      [
        "inlineCode": "",
        "resourceUri": ""
      ]
    ]
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")! 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 bigquery.tables.setIamPolicy
{{baseUrl}}/: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}}/: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}}/: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}}/: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}}/: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}}/: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}}/: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/: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}}/: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}}/: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}}/:resource:setIamPolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/: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}}/:resource:setIamPolicy');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/: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}}/: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}}/: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}}/: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/: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}}/: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}}/: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}}/: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}}/: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}}/: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}}/: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}}/: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}}/: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}}/: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}}/: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}}/: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}}/: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/:resource:setIamPolicy", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/: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}}/: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}}/: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/: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}}/: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}}/: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}}/: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}}/: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}}/: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 bigquery.tables.testIamPermissions
{{baseUrl}}/: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}}/: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}}/:resource:testIamPermissions" {:content-type :json
                                                                         :form-params {:permissions []}})
require "http/client"

url = "{{baseUrl}}/: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}}/: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}}/: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}}/: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/:resource:testIamPermissions HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 23

{
  "permissions": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/: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}}/: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}}/:resource:testIamPermissions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/: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}}/:resource:testIamPermissions');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/: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}}/: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}}/: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}}/: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/: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}}/: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}}/: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}}/: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}}/: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}}/: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}}/: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}}/: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}}/:resource:testIamPermissions', [
  'body' => '{
  "permissions": []
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/: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}}/: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}}/:resource:testIamPermissions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "permissions": []
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/: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/:resource:testIamPermissions", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/:resource:testIamPermissions"

payload = { "permissions": [] }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/: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}}/: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/: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}}/: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}}/:resource:testIamPermissions \
  --header 'content-type: application/json' \
  --data '{
  "permissions": []
}'
echo '{
  "permissions": []
}' |  \
  http POST {{baseUrl}}/:resource:testIamPermissions \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "permissions": []\n}' \
  --output-document \
  - {{baseUrl}}/: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}}/: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()
PUT bigquery.tables.update
{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId
QUERY PARAMS

projectId
datasetId
tableId
BODY json

{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId" {:content-type :json
                                                                                                   :form-params {:cloneDefinition {:baseTableReference {:datasetId ""
                                                                                                                                                        :projectId ""
                                                                                                                                                        :tableId ""}
                                                                                                                                   :cloneTime ""}
                                                                                                                 :clustering {:fields []}
                                                                                                                 :creationTime ""
                                                                                                                 :defaultCollation ""
                                                                                                                 :defaultRoundingMode ""
                                                                                                                 :description ""
                                                                                                                 :encryptionConfiguration {:kmsKeyName ""}
                                                                                                                 :etag ""
                                                                                                                 :expirationTime ""
                                                                                                                 :externalDataConfiguration {:autodetect false
                                                                                                                                             :avroOptions {:useAvroLogicalTypes false}
                                                                                                                                             :bigtableOptions {:columnFamilies [{:columns [{:encoding ""
                                                                                                                                                                                            :fieldName ""
                                                                                                                                                                                            :onlyReadLatest false
                                                                                                                                                                                            :qualifierEncoded ""
                                                                                                                                                                                            :qualifierString ""
                                                                                                                                                                                            :type ""}]
                                                                                                                                                                                 :encoding ""
                                                                                                                                                                                 :familyId ""
                                                                                                                                                                                 :onlyReadLatest false
                                                                                                                                                                                 :type ""}]
                                                                                                                                                               :ignoreUnspecifiedColumnFamilies false
                                                                                                                                                               :readRowkeyAsString false}
                                                                                                                                             :compression ""
                                                                                                                                             :connectionId ""
                                                                                                                                             :csvOptions {:allowJaggedRows false
                                                                                                                                                          :allowQuotedNewlines false
                                                                                                                                                          :encoding ""
                                                                                                                                                          :fieldDelimiter ""
                                                                                                                                                          :null_marker ""
                                                                                                                                                          :preserveAsciiControlCharacters false
                                                                                                                                                          :quote ""
                                                                                                                                                          :skipLeadingRows ""}
                                                                                                                                             :decimalTargetTypes []
                                                                                                                                             :googleSheetsOptions {:range ""
                                                                                                                                                                   :skipLeadingRows ""}
                                                                                                                                             :hivePartitioningOptions {:mode ""
                                                                                                                                                                       :requirePartitionFilter false
                                                                                                                                                                       :sourceUriPrefix ""}
                                                                                                                                             :ignoreUnknownValues false
                                                                                                                                             :maxBadRecords 0
                                                                                                                                             :metadataCacheMode ""
                                                                                                                                             :objectMetadata ""
                                                                                                                                             :parquetOptions {:enableListInference false
                                                                                                                                                              :enumAsString false}
                                                                                                                                             :referenceFileSchemaUri ""
                                                                                                                                             :schema {:fields [{:categories {:names []}
                                                                                                                                                                :collation ""
                                                                                                                                                                :defaultValueExpression ""
                                                                                                                                                                :description ""
                                                                                                                                                                :fields []
                                                                                                                                                                :maxLength ""
                                                                                                                                                                :mode ""
                                                                                                                                                                :name ""
                                                                                                                                                                :policyTags {:names []}
                                                                                                                                                                :precision ""
                                                                                                                                                                :roundingMode ""
                                                                                                                                                                :scale ""
                                                                                                                                                                :type ""}]}
                                                                                                                                             :sourceFormat ""
                                                                                                                                             :sourceUris []}
                                                                                                                 :friendlyName ""
                                                                                                                 :id ""
                                                                                                                 :kind ""
                                                                                                                 :labels {}
                                                                                                                 :lastModifiedTime ""
                                                                                                                 :location ""
                                                                                                                 :materializedView {:allow_non_incremental_definition false
                                                                                                                                    :enableRefresh false
                                                                                                                                    :lastRefreshTime ""
                                                                                                                                    :maxStaleness ""
                                                                                                                                    :query ""
                                                                                                                                    :refreshIntervalMs ""}
                                                                                                                 :maxStaleness ""
                                                                                                                 :model {:modelOptions {:labels []
                                                                                                                                        :lossType ""
                                                                                                                                        :modelType ""}
                                                                                                                         :trainingRuns [{:iterationResults [{:durationMs ""
                                                                                                                                                             :evalLoss ""
                                                                                                                                                             :index 0
                                                                                                                                                             :learnRate ""
                                                                                                                                                             :trainingLoss ""}]
                                                                                                                                         :startTime ""
                                                                                                                                         :state ""
                                                                                                                                         :trainingOptions {:earlyStop false
                                                                                                                                                           :l1Reg ""
                                                                                                                                                           :l2Reg ""
                                                                                                                                                           :learnRate ""
                                                                                                                                                           :learnRateStrategy ""
                                                                                                                                                           :lineSearchInitLearnRate ""
                                                                                                                                                           :maxIteration ""
                                                                                                                                                           :minRelProgress ""
                                                                                                                                                           :warmStart false}}]}
                                                                                                                 :numBytes ""
                                                                                                                 :numLongTermBytes ""
                                                                                                                 :numPhysicalBytes ""
                                                                                                                 :numRows ""
                                                                                                                 :num_active_logical_bytes ""
                                                                                                                 :num_active_physical_bytes ""
                                                                                                                 :num_long_term_logical_bytes ""
                                                                                                                 :num_long_term_physical_bytes ""
                                                                                                                 :num_partitions ""
                                                                                                                 :num_time_travel_physical_bytes ""
                                                                                                                 :num_total_logical_bytes ""
                                                                                                                 :num_total_physical_bytes ""
                                                                                                                 :rangePartitioning {:field ""
                                                                                                                                     :range {:end ""
                                                                                                                                             :interval ""
                                                                                                                                             :start ""}}
                                                                                                                 :requirePartitionFilter false
                                                                                                                 :schema {}
                                                                                                                 :selfLink ""
                                                                                                                 :snapshotDefinition {:baseTableReference {}
                                                                                                                                      :snapshotTime ""}
                                                                                                                 :streamingBuffer {:estimatedBytes ""
                                                                                                                                   :estimatedRows ""
                                                                                                                                   :oldestEntryTime ""}
                                                                                                                 :tableReference {}
                                                                                                                 :timePartitioning {:expirationMs ""
                                                                                                                                    :field ""
                                                                                                                                    :requirePartitionFilter false
                                                                                                                                    :type ""}
                                                                                                                 :type ""
                                                                                                                 :view {:query ""
                                                                                                                        :useExplicitColumnNames false
                                                                                                                        :useLegacySql false
                                                                                                                        :userDefinedFunctionResources [{:inlineCode ""
                                                                                                                                                        :resourceUri ""}]}}})
require "http/client"

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"),
    Content = new StringContent("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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}}/projects/:projectId/datasets/:datasetId/tables/:tableId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

	payload := strings.NewReader("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}")

	req, _ := http.NewRequest("PUT", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
PUT /baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 4536

{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\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  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .header("content-type", "application/json")
  .body("{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}")
  .asString();
const data = JSON.stringify({
  cloneDefinition: {
    baseTableReference: {
      datasetId: '',
      projectId: '',
      tableId: ''
    },
    cloneTime: ''
  },
  clustering: {
    fields: []
  },
  creationTime: '',
  defaultCollation: '',
  defaultRoundingMode: '',
  description: '',
  encryptionConfiguration: {
    kmsKeyName: ''
  },
  etag: '',
  expirationTime: '',
  externalDataConfiguration: {
    autodetect: false,
    avroOptions: {
      useAvroLogicalTypes: false
    },
    bigtableOptions: {
      columnFamilies: [
        {
          columns: [
            {
              encoding: '',
              fieldName: '',
              onlyReadLatest: false,
              qualifierEncoded: '',
              qualifierString: '',
              type: ''
            }
          ],
          encoding: '',
          familyId: '',
          onlyReadLatest: false,
          type: ''
        }
      ],
      ignoreUnspecifiedColumnFamilies: false,
      readRowkeyAsString: false
    },
    compression: '',
    connectionId: '',
    csvOptions: {
      allowJaggedRows: false,
      allowQuotedNewlines: false,
      encoding: '',
      fieldDelimiter: '',
      null_marker: '',
      preserveAsciiControlCharacters: false,
      quote: '',
      skipLeadingRows: ''
    },
    decimalTargetTypes: [],
    googleSheetsOptions: {
      range: '',
      skipLeadingRows: ''
    },
    hivePartitioningOptions: {
      mode: '',
      requirePartitionFilter: false,
      sourceUriPrefix: ''
    },
    ignoreUnknownValues: false,
    maxBadRecords: 0,
    metadataCacheMode: '',
    objectMetadata: '',
    parquetOptions: {
      enableListInference: false,
      enumAsString: false
    },
    referenceFileSchemaUri: '',
    schema: {
      fields: [
        {
          categories: {
            names: []
          },
          collation: '',
          defaultValueExpression: '',
          description: '',
          fields: [],
          maxLength: '',
          mode: '',
          name: '',
          policyTags: {
            names: []
          },
          precision: '',
          roundingMode: '',
          scale: '',
          type: ''
        }
      ]
    },
    sourceFormat: '',
    sourceUris: []
  },
  friendlyName: '',
  id: '',
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  materializedView: {
    allow_non_incremental_definition: false,
    enableRefresh: false,
    lastRefreshTime: '',
    maxStaleness: '',
    query: '',
    refreshIntervalMs: ''
  },
  maxStaleness: '',
  model: {
    modelOptions: {
      labels: [],
      lossType: '',
      modelType: ''
    },
    trainingRuns: [
      {
        iterationResults: [
          {
            durationMs: '',
            evalLoss: '',
            index: 0,
            learnRate: '',
            trainingLoss: ''
          }
        ],
        startTime: '',
        state: '',
        trainingOptions: {
          earlyStop: false,
          l1Reg: '',
          l2Reg: '',
          learnRate: '',
          learnRateStrategy: '',
          lineSearchInitLearnRate: '',
          maxIteration: '',
          minRelProgress: '',
          warmStart: false
        }
      }
    ]
  },
  numBytes: '',
  numLongTermBytes: '',
  numPhysicalBytes: '',
  numRows: '',
  num_active_logical_bytes: '',
  num_active_physical_bytes: '',
  num_long_term_logical_bytes: '',
  num_long_term_physical_bytes: '',
  num_partitions: '',
  num_time_travel_physical_bytes: '',
  num_total_logical_bytes: '',
  num_total_physical_bytes: '',
  rangePartitioning: {
    field: '',
    range: {
      end: '',
      interval: '',
      start: ''
    }
  },
  requirePartitionFilter: false,
  schema: {},
  selfLink: '',
  snapshotDefinition: {
    baseTableReference: {},
    snapshotTime: ''
  },
  streamingBuffer: {
    estimatedBytes: '',
    estimatedRows: '',
    oldestEntryTime: ''
  },
  tableReference: {},
  timePartitioning: {
    expirationMs: '',
    field: '',
    requirePartitionFilter: false,
    type: ''
  },
  type: '',
  view: {
    query: '',
    useExplicitColumnNames: false,
    useLegacySql: false,
    userDefinedFunctionResources: [
      {
        inlineCode: '',
        resourceUri: ''
      }
    ]
  }
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId',
  headers: {'content-type': 'application/json'},
  data: {
    cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
    clustering: {fields: []},
    creationTime: '',
    defaultCollation: '',
    defaultRoundingMode: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    externalDataConfiguration: {
      autodetect: false,
      avroOptions: {useAvroLogicalTypes: false},
      bigtableOptions: {
        columnFamilies: [
          {
            columns: [
              {
                encoding: '',
                fieldName: '',
                onlyReadLatest: false,
                qualifierEncoded: '',
                qualifierString: '',
                type: ''
              }
            ],
            encoding: '',
            familyId: '',
            onlyReadLatest: false,
            type: ''
          }
        ],
        ignoreUnspecifiedColumnFamilies: false,
        readRowkeyAsString: false
      },
      compression: '',
      connectionId: '',
      csvOptions: {
        allowJaggedRows: false,
        allowQuotedNewlines: false,
        encoding: '',
        fieldDelimiter: '',
        null_marker: '',
        preserveAsciiControlCharacters: false,
        quote: '',
        skipLeadingRows: ''
      },
      decimalTargetTypes: [],
      googleSheetsOptions: {range: '', skipLeadingRows: ''},
      hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
      ignoreUnknownValues: false,
      maxBadRecords: 0,
      metadataCacheMode: '',
      objectMetadata: '',
      parquetOptions: {enableListInference: false, enumAsString: false},
      referenceFileSchemaUri: '',
      schema: {
        fields: [
          {
            categories: {names: []},
            collation: '',
            defaultValueExpression: '',
            description: '',
            fields: [],
            maxLength: '',
            mode: '',
            name: '',
            policyTags: {names: []},
            precision: '',
            roundingMode: '',
            scale: '',
            type: ''
          }
        ]
      },
      sourceFormat: '',
      sourceUris: []
    },
    friendlyName: '',
    id: '',
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    materializedView: {
      allow_non_incremental_definition: false,
      enableRefresh: false,
      lastRefreshTime: '',
      maxStaleness: '',
      query: '',
      refreshIntervalMs: ''
    },
    maxStaleness: '',
    model: {
      modelOptions: {labels: [], lossType: '', modelType: ''},
      trainingRuns: [
        {
          iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
          startTime: '',
          state: '',
          trainingOptions: {
            earlyStop: false,
            l1Reg: '',
            l2Reg: '',
            learnRate: '',
            learnRateStrategy: '',
            lineSearchInitLearnRate: '',
            maxIteration: '',
            minRelProgress: '',
            warmStart: false
          }
        }
      ]
    },
    numBytes: '',
    numLongTermBytes: '',
    numPhysicalBytes: '',
    numRows: '',
    num_active_logical_bytes: '',
    num_active_physical_bytes: '',
    num_long_term_logical_bytes: '',
    num_long_term_physical_bytes: '',
    num_partitions: '',
    num_time_travel_physical_bytes: '',
    num_total_logical_bytes: '',
    num_total_physical_bytes: '',
    rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
    requirePartitionFilter: false,
    schema: {},
    selfLink: '',
    snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
    streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
    tableReference: {},
    timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
    type: '',
    view: {
      query: '',
      useExplicitColumnNames: false,
      useLegacySql: false,
      userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"cloneDefinition":{"baseTableReference":{"datasetId":"","projectId":"","tableId":""},"cloneTime":""},"clustering":{"fields":[]},"creationTime":"","defaultCollation":"","defaultRoundingMode":"","description":"","encryptionConfiguration":{"kmsKeyName":""},"etag":"","expirationTime":"","externalDataConfiguration":{"autodetect":false,"avroOptions":{"useAvroLogicalTypes":false},"bigtableOptions":{"columnFamilies":[{"columns":[{"encoding":"","fieldName":"","onlyReadLatest":false,"qualifierEncoded":"","qualifierString":"","type":""}],"encoding":"","familyId":"","onlyReadLatest":false,"type":""}],"ignoreUnspecifiedColumnFamilies":false,"readRowkeyAsString":false},"compression":"","connectionId":"","csvOptions":{"allowJaggedRows":false,"allowQuotedNewlines":false,"encoding":"","fieldDelimiter":"","null_marker":"","preserveAsciiControlCharacters":false,"quote":"","skipLeadingRows":""},"decimalTargetTypes":[],"googleSheetsOptions":{"range":"","skipLeadingRows":""},"hivePartitioningOptions":{"mode":"","requirePartitionFilter":false,"sourceUriPrefix":""},"ignoreUnknownValues":false,"maxBadRecords":0,"metadataCacheMode":"","objectMetadata":"","parquetOptions":{"enableListInference":false,"enumAsString":false},"referenceFileSchemaUri":"","schema":{"fields":[{"categories":{"names":[]},"collation":"","defaultValueExpression":"","description":"","fields":[],"maxLength":"","mode":"","name":"","policyTags":{"names":[]},"precision":"","roundingMode":"","scale":"","type":""}]},"sourceFormat":"","sourceUris":[]},"friendlyName":"","id":"","kind":"","labels":{},"lastModifiedTime":"","location":"","materializedView":{"allow_non_incremental_definition":false,"enableRefresh":false,"lastRefreshTime":"","maxStaleness":"","query":"","refreshIntervalMs":""},"maxStaleness":"","model":{"modelOptions":{"labels":[],"lossType":"","modelType":""},"trainingRuns":[{"iterationResults":[{"durationMs":"","evalLoss":"","index":0,"learnRate":"","trainingLoss":""}],"startTime":"","state":"","trainingOptions":{"earlyStop":false,"l1Reg":"","l2Reg":"","learnRate":"","learnRateStrategy":"","lineSearchInitLearnRate":"","maxIteration":"","minRelProgress":"","warmStart":false}}]},"numBytes":"","numLongTermBytes":"","numPhysicalBytes":"","numRows":"","num_active_logical_bytes":"","num_active_physical_bytes":"","num_long_term_logical_bytes":"","num_long_term_physical_bytes":"","num_partitions":"","num_time_travel_physical_bytes":"","num_total_logical_bytes":"","num_total_physical_bytes":"","rangePartitioning":{"field":"","range":{"end":"","interval":"","start":""}},"requirePartitionFilter":false,"schema":{},"selfLink":"","snapshotDefinition":{"baseTableReference":{},"snapshotTime":""},"streamingBuffer":{"estimatedBytes":"","estimatedRows":"","oldestEntryTime":""},"tableReference":{},"timePartitioning":{"expirationMs":"","field":"","requirePartitionFilter":false,"type":""},"type":"","view":{"query":"","useExplicitColumnNames":false,"useLegacySql":false,"userDefinedFunctionResources":[{"inlineCode":"","resourceUri":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cloneDefinition": {\n    "baseTableReference": {\n      "datasetId": "",\n      "projectId": "",\n      "tableId": ""\n    },\n    "cloneTime": ""\n  },\n  "clustering": {\n    "fields": []\n  },\n  "creationTime": "",\n  "defaultCollation": "",\n  "defaultRoundingMode": "",\n  "description": "",\n  "encryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "etag": "",\n  "expirationTime": "",\n  "externalDataConfiguration": {\n    "autodetect": false,\n    "avroOptions": {\n      "useAvroLogicalTypes": false\n    },\n    "bigtableOptions": {\n      "columnFamilies": [\n        {\n          "columns": [\n            {\n              "encoding": "",\n              "fieldName": "",\n              "onlyReadLatest": false,\n              "qualifierEncoded": "",\n              "qualifierString": "",\n              "type": ""\n            }\n          ],\n          "encoding": "",\n          "familyId": "",\n          "onlyReadLatest": false,\n          "type": ""\n        }\n      ],\n      "ignoreUnspecifiedColumnFamilies": false,\n      "readRowkeyAsString": false\n    },\n    "compression": "",\n    "connectionId": "",\n    "csvOptions": {\n      "allowJaggedRows": false,\n      "allowQuotedNewlines": false,\n      "encoding": "",\n      "fieldDelimiter": "",\n      "null_marker": "",\n      "preserveAsciiControlCharacters": false,\n      "quote": "",\n      "skipLeadingRows": ""\n    },\n    "decimalTargetTypes": [],\n    "googleSheetsOptions": {\n      "range": "",\n      "skipLeadingRows": ""\n    },\n    "hivePartitioningOptions": {\n      "mode": "",\n      "requirePartitionFilter": false,\n      "sourceUriPrefix": ""\n    },\n    "ignoreUnknownValues": false,\n    "maxBadRecords": 0,\n    "metadataCacheMode": "",\n    "objectMetadata": "",\n    "parquetOptions": {\n      "enableListInference": false,\n      "enumAsString": false\n    },\n    "referenceFileSchemaUri": "",\n    "schema": {\n      "fields": [\n        {\n          "categories": {\n            "names": []\n          },\n          "collation": "",\n          "defaultValueExpression": "",\n          "description": "",\n          "fields": [],\n          "maxLength": "",\n          "mode": "",\n          "name": "",\n          "policyTags": {\n            "names": []\n          },\n          "precision": "",\n          "roundingMode": "",\n          "scale": "",\n          "type": ""\n        }\n      ]\n    },\n    "sourceFormat": "",\n    "sourceUris": []\n  },\n  "friendlyName": "",\n  "id": "",\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "materializedView": {\n    "allow_non_incremental_definition": false,\n    "enableRefresh": false,\n    "lastRefreshTime": "",\n    "maxStaleness": "",\n    "query": "",\n    "refreshIntervalMs": ""\n  },\n  "maxStaleness": "",\n  "model": {\n    "modelOptions": {\n      "labels": [],\n      "lossType": "",\n      "modelType": ""\n    },\n    "trainingRuns": [\n      {\n        "iterationResults": [\n          {\n            "durationMs": "",\n            "evalLoss": "",\n            "index": 0,\n            "learnRate": "",\n            "trainingLoss": ""\n          }\n        ],\n        "startTime": "",\n        "state": "",\n        "trainingOptions": {\n          "earlyStop": false,\n          "l1Reg": "",\n          "l2Reg": "",\n          "learnRate": "",\n          "learnRateStrategy": "",\n          "lineSearchInitLearnRate": "",\n          "maxIteration": "",\n          "minRelProgress": "",\n          "warmStart": false\n        }\n      }\n    ]\n  },\n  "numBytes": "",\n  "numLongTermBytes": "",\n  "numPhysicalBytes": "",\n  "numRows": "",\n  "num_active_logical_bytes": "",\n  "num_active_physical_bytes": "",\n  "num_long_term_logical_bytes": "",\n  "num_long_term_physical_bytes": "",\n  "num_partitions": "",\n  "num_time_travel_physical_bytes": "",\n  "num_total_logical_bytes": "",\n  "num_total_physical_bytes": "",\n  "rangePartitioning": {\n    "field": "",\n    "range": {\n      "end": "",\n      "interval": "",\n      "start": ""\n    }\n  },\n  "requirePartitionFilter": false,\n  "schema": {},\n  "selfLink": "",\n  "snapshotDefinition": {\n    "baseTableReference": {},\n    "snapshotTime": ""\n  },\n  "streamingBuffer": {\n    "estimatedBytes": "",\n    "estimatedRows": "",\n    "oldestEntryTime": ""\n  },\n  "tableReference": {},\n  "timePartitioning": {\n    "expirationMs": "",\n    "field": "",\n    "requirePartitionFilter": false,\n    "type": ""\n  },\n  "type": "",\n  "view": {\n    "query": "",\n    "useExplicitColumnNames": false,\n    "useLegacySql": false,\n    "userDefinedFunctionResources": [\n      {\n        "inlineCode": "",\n        "resourceUri": ""\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  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'PUT',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
  clustering: {fields: []},
  creationTime: '',
  defaultCollation: '',
  defaultRoundingMode: '',
  description: '',
  encryptionConfiguration: {kmsKeyName: ''},
  etag: '',
  expirationTime: '',
  externalDataConfiguration: {
    autodetect: false,
    avroOptions: {useAvroLogicalTypes: false},
    bigtableOptions: {
      columnFamilies: [
        {
          columns: [
            {
              encoding: '',
              fieldName: '',
              onlyReadLatest: false,
              qualifierEncoded: '',
              qualifierString: '',
              type: ''
            }
          ],
          encoding: '',
          familyId: '',
          onlyReadLatest: false,
          type: ''
        }
      ],
      ignoreUnspecifiedColumnFamilies: false,
      readRowkeyAsString: false
    },
    compression: '',
    connectionId: '',
    csvOptions: {
      allowJaggedRows: false,
      allowQuotedNewlines: false,
      encoding: '',
      fieldDelimiter: '',
      null_marker: '',
      preserveAsciiControlCharacters: false,
      quote: '',
      skipLeadingRows: ''
    },
    decimalTargetTypes: [],
    googleSheetsOptions: {range: '', skipLeadingRows: ''},
    hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
    ignoreUnknownValues: false,
    maxBadRecords: 0,
    metadataCacheMode: '',
    objectMetadata: '',
    parquetOptions: {enableListInference: false, enumAsString: false},
    referenceFileSchemaUri: '',
    schema: {
      fields: [
        {
          categories: {names: []},
          collation: '',
          defaultValueExpression: '',
          description: '',
          fields: [],
          maxLength: '',
          mode: '',
          name: '',
          policyTags: {names: []},
          precision: '',
          roundingMode: '',
          scale: '',
          type: ''
        }
      ]
    },
    sourceFormat: '',
    sourceUris: []
  },
  friendlyName: '',
  id: '',
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  materializedView: {
    allow_non_incremental_definition: false,
    enableRefresh: false,
    lastRefreshTime: '',
    maxStaleness: '',
    query: '',
    refreshIntervalMs: ''
  },
  maxStaleness: '',
  model: {
    modelOptions: {labels: [], lossType: '', modelType: ''},
    trainingRuns: [
      {
        iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
        startTime: '',
        state: '',
        trainingOptions: {
          earlyStop: false,
          l1Reg: '',
          l2Reg: '',
          learnRate: '',
          learnRateStrategy: '',
          lineSearchInitLearnRate: '',
          maxIteration: '',
          minRelProgress: '',
          warmStart: false
        }
      }
    ]
  },
  numBytes: '',
  numLongTermBytes: '',
  numPhysicalBytes: '',
  numRows: '',
  num_active_logical_bytes: '',
  num_active_physical_bytes: '',
  num_long_term_logical_bytes: '',
  num_long_term_physical_bytes: '',
  num_partitions: '',
  num_time_travel_physical_bytes: '',
  num_total_logical_bytes: '',
  num_total_physical_bytes: '',
  rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
  requirePartitionFilter: false,
  schema: {},
  selfLink: '',
  snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
  streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
  tableReference: {},
  timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
  type: '',
  view: {
    query: '',
    useExplicitColumnNames: false,
    useLegacySql: false,
    userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId',
  headers: {'content-type': 'application/json'},
  body: {
    cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
    clustering: {fields: []},
    creationTime: '',
    defaultCollation: '',
    defaultRoundingMode: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    externalDataConfiguration: {
      autodetect: false,
      avroOptions: {useAvroLogicalTypes: false},
      bigtableOptions: {
        columnFamilies: [
          {
            columns: [
              {
                encoding: '',
                fieldName: '',
                onlyReadLatest: false,
                qualifierEncoded: '',
                qualifierString: '',
                type: ''
              }
            ],
            encoding: '',
            familyId: '',
            onlyReadLatest: false,
            type: ''
          }
        ],
        ignoreUnspecifiedColumnFamilies: false,
        readRowkeyAsString: false
      },
      compression: '',
      connectionId: '',
      csvOptions: {
        allowJaggedRows: false,
        allowQuotedNewlines: false,
        encoding: '',
        fieldDelimiter: '',
        null_marker: '',
        preserveAsciiControlCharacters: false,
        quote: '',
        skipLeadingRows: ''
      },
      decimalTargetTypes: [],
      googleSheetsOptions: {range: '', skipLeadingRows: ''},
      hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
      ignoreUnknownValues: false,
      maxBadRecords: 0,
      metadataCacheMode: '',
      objectMetadata: '',
      parquetOptions: {enableListInference: false, enumAsString: false},
      referenceFileSchemaUri: '',
      schema: {
        fields: [
          {
            categories: {names: []},
            collation: '',
            defaultValueExpression: '',
            description: '',
            fields: [],
            maxLength: '',
            mode: '',
            name: '',
            policyTags: {names: []},
            precision: '',
            roundingMode: '',
            scale: '',
            type: ''
          }
        ]
      },
      sourceFormat: '',
      sourceUris: []
    },
    friendlyName: '',
    id: '',
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    materializedView: {
      allow_non_incremental_definition: false,
      enableRefresh: false,
      lastRefreshTime: '',
      maxStaleness: '',
      query: '',
      refreshIntervalMs: ''
    },
    maxStaleness: '',
    model: {
      modelOptions: {labels: [], lossType: '', modelType: ''},
      trainingRuns: [
        {
          iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
          startTime: '',
          state: '',
          trainingOptions: {
            earlyStop: false,
            l1Reg: '',
            l2Reg: '',
            learnRate: '',
            learnRateStrategy: '',
            lineSearchInitLearnRate: '',
            maxIteration: '',
            minRelProgress: '',
            warmStart: false
          }
        }
      ]
    },
    numBytes: '',
    numLongTermBytes: '',
    numPhysicalBytes: '',
    numRows: '',
    num_active_logical_bytes: '',
    num_active_physical_bytes: '',
    num_long_term_logical_bytes: '',
    num_long_term_physical_bytes: '',
    num_partitions: '',
    num_time_travel_physical_bytes: '',
    num_total_logical_bytes: '',
    num_total_physical_bytes: '',
    rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
    requirePartitionFilter: false,
    schema: {},
    selfLink: '',
    snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
    streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
    tableReference: {},
    timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
    type: '',
    view: {
      query: '',
      useExplicitColumnNames: false,
      useLegacySql: false,
      userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
    }
  },
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('PUT', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  cloneDefinition: {
    baseTableReference: {
      datasetId: '',
      projectId: '',
      tableId: ''
    },
    cloneTime: ''
  },
  clustering: {
    fields: []
  },
  creationTime: '',
  defaultCollation: '',
  defaultRoundingMode: '',
  description: '',
  encryptionConfiguration: {
    kmsKeyName: ''
  },
  etag: '',
  expirationTime: '',
  externalDataConfiguration: {
    autodetect: false,
    avroOptions: {
      useAvroLogicalTypes: false
    },
    bigtableOptions: {
      columnFamilies: [
        {
          columns: [
            {
              encoding: '',
              fieldName: '',
              onlyReadLatest: false,
              qualifierEncoded: '',
              qualifierString: '',
              type: ''
            }
          ],
          encoding: '',
          familyId: '',
          onlyReadLatest: false,
          type: ''
        }
      ],
      ignoreUnspecifiedColumnFamilies: false,
      readRowkeyAsString: false
    },
    compression: '',
    connectionId: '',
    csvOptions: {
      allowJaggedRows: false,
      allowQuotedNewlines: false,
      encoding: '',
      fieldDelimiter: '',
      null_marker: '',
      preserveAsciiControlCharacters: false,
      quote: '',
      skipLeadingRows: ''
    },
    decimalTargetTypes: [],
    googleSheetsOptions: {
      range: '',
      skipLeadingRows: ''
    },
    hivePartitioningOptions: {
      mode: '',
      requirePartitionFilter: false,
      sourceUriPrefix: ''
    },
    ignoreUnknownValues: false,
    maxBadRecords: 0,
    metadataCacheMode: '',
    objectMetadata: '',
    parquetOptions: {
      enableListInference: false,
      enumAsString: false
    },
    referenceFileSchemaUri: '',
    schema: {
      fields: [
        {
          categories: {
            names: []
          },
          collation: '',
          defaultValueExpression: '',
          description: '',
          fields: [],
          maxLength: '',
          mode: '',
          name: '',
          policyTags: {
            names: []
          },
          precision: '',
          roundingMode: '',
          scale: '',
          type: ''
        }
      ]
    },
    sourceFormat: '',
    sourceUris: []
  },
  friendlyName: '',
  id: '',
  kind: '',
  labels: {},
  lastModifiedTime: '',
  location: '',
  materializedView: {
    allow_non_incremental_definition: false,
    enableRefresh: false,
    lastRefreshTime: '',
    maxStaleness: '',
    query: '',
    refreshIntervalMs: ''
  },
  maxStaleness: '',
  model: {
    modelOptions: {
      labels: [],
      lossType: '',
      modelType: ''
    },
    trainingRuns: [
      {
        iterationResults: [
          {
            durationMs: '',
            evalLoss: '',
            index: 0,
            learnRate: '',
            trainingLoss: ''
          }
        ],
        startTime: '',
        state: '',
        trainingOptions: {
          earlyStop: false,
          l1Reg: '',
          l2Reg: '',
          learnRate: '',
          learnRateStrategy: '',
          lineSearchInitLearnRate: '',
          maxIteration: '',
          minRelProgress: '',
          warmStart: false
        }
      }
    ]
  },
  numBytes: '',
  numLongTermBytes: '',
  numPhysicalBytes: '',
  numRows: '',
  num_active_logical_bytes: '',
  num_active_physical_bytes: '',
  num_long_term_logical_bytes: '',
  num_long_term_physical_bytes: '',
  num_partitions: '',
  num_time_travel_physical_bytes: '',
  num_total_logical_bytes: '',
  num_total_physical_bytes: '',
  rangePartitioning: {
    field: '',
    range: {
      end: '',
      interval: '',
      start: ''
    }
  },
  requirePartitionFilter: false,
  schema: {},
  selfLink: '',
  snapshotDefinition: {
    baseTableReference: {},
    snapshotTime: ''
  },
  streamingBuffer: {
    estimatedBytes: '',
    estimatedRows: '',
    oldestEntryTime: ''
  },
  tableReference: {},
  timePartitioning: {
    expirationMs: '',
    field: '',
    requirePartitionFilter: false,
    type: ''
  },
  type: '',
  view: {
    query: '',
    useExplicitColumnNames: false,
    useLegacySql: false,
    userDefinedFunctionResources: [
      {
        inlineCode: '',
        resourceUri: ''
      }
    ]
  }
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId',
  headers: {'content-type': 'application/json'},
  data: {
    cloneDefinition: {baseTableReference: {datasetId: '', projectId: '', tableId: ''}, cloneTime: ''},
    clustering: {fields: []},
    creationTime: '',
    defaultCollation: '',
    defaultRoundingMode: '',
    description: '',
    encryptionConfiguration: {kmsKeyName: ''},
    etag: '',
    expirationTime: '',
    externalDataConfiguration: {
      autodetect: false,
      avroOptions: {useAvroLogicalTypes: false},
      bigtableOptions: {
        columnFamilies: [
          {
            columns: [
              {
                encoding: '',
                fieldName: '',
                onlyReadLatest: false,
                qualifierEncoded: '',
                qualifierString: '',
                type: ''
              }
            ],
            encoding: '',
            familyId: '',
            onlyReadLatest: false,
            type: ''
          }
        ],
        ignoreUnspecifiedColumnFamilies: false,
        readRowkeyAsString: false
      },
      compression: '',
      connectionId: '',
      csvOptions: {
        allowJaggedRows: false,
        allowQuotedNewlines: false,
        encoding: '',
        fieldDelimiter: '',
        null_marker: '',
        preserveAsciiControlCharacters: false,
        quote: '',
        skipLeadingRows: ''
      },
      decimalTargetTypes: [],
      googleSheetsOptions: {range: '', skipLeadingRows: ''},
      hivePartitioningOptions: {mode: '', requirePartitionFilter: false, sourceUriPrefix: ''},
      ignoreUnknownValues: false,
      maxBadRecords: 0,
      metadataCacheMode: '',
      objectMetadata: '',
      parquetOptions: {enableListInference: false, enumAsString: false},
      referenceFileSchemaUri: '',
      schema: {
        fields: [
          {
            categories: {names: []},
            collation: '',
            defaultValueExpression: '',
            description: '',
            fields: [],
            maxLength: '',
            mode: '',
            name: '',
            policyTags: {names: []},
            precision: '',
            roundingMode: '',
            scale: '',
            type: ''
          }
        ]
      },
      sourceFormat: '',
      sourceUris: []
    },
    friendlyName: '',
    id: '',
    kind: '',
    labels: {},
    lastModifiedTime: '',
    location: '',
    materializedView: {
      allow_non_incremental_definition: false,
      enableRefresh: false,
      lastRefreshTime: '',
      maxStaleness: '',
      query: '',
      refreshIntervalMs: ''
    },
    maxStaleness: '',
    model: {
      modelOptions: {labels: [], lossType: '', modelType: ''},
      trainingRuns: [
        {
          iterationResults: [{durationMs: '', evalLoss: '', index: 0, learnRate: '', trainingLoss: ''}],
          startTime: '',
          state: '',
          trainingOptions: {
            earlyStop: false,
            l1Reg: '',
            l2Reg: '',
            learnRate: '',
            learnRateStrategy: '',
            lineSearchInitLearnRate: '',
            maxIteration: '',
            minRelProgress: '',
            warmStart: false
          }
        }
      ]
    },
    numBytes: '',
    numLongTermBytes: '',
    numPhysicalBytes: '',
    numRows: '',
    num_active_logical_bytes: '',
    num_active_physical_bytes: '',
    num_long_term_logical_bytes: '',
    num_long_term_physical_bytes: '',
    num_partitions: '',
    num_time_travel_physical_bytes: '',
    num_total_logical_bytes: '',
    num_total_physical_bytes: '',
    rangePartitioning: {field: '', range: {end: '', interval: '', start: ''}},
    requirePartitionFilter: false,
    schema: {},
    selfLink: '',
    snapshotDefinition: {baseTableReference: {}, snapshotTime: ''},
    streamingBuffer: {estimatedBytes: '', estimatedRows: '', oldestEntryTime: ''},
    tableReference: {},
    timePartitioning: {expirationMs: '', field: '', requirePartitionFilter: false, type: ''},
    type: '',
    view: {
      query: '',
      useExplicitColumnNames: false,
      useLegacySql: false,
      userDefinedFunctionResources: [{inlineCode: '', resourceUri: ''}]
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"cloneDefinition":{"baseTableReference":{"datasetId":"","projectId":"","tableId":""},"cloneTime":""},"clustering":{"fields":[]},"creationTime":"","defaultCollation":"","defaultRoundingMode":"","description":"","encryptionConfiguration":{"kmsKeyName":""},"etag":"","expirationTime":"","externalDataConfiguration":{"autodetect":false,"avroOptions":{"useAvroLogicalTypes":false},"bigtableOptions":{"columnFamilies":[{"columns":[{"encoding":"","fieldName":"","onlyReadLatest":false,"qualifierEncoded":"","qualifierString":"","type":""}],"encoding":"","familyId":"","onlyReadLatest":false,"type":""}],"ignoreUnspecifiedColumnFamilies":false,"readRowkeyAsString":false},"compression":"","connectionId":"","csvOptions":{"allowJaggedRows":false,"allowQuotedNewlines":false,"encoding":"","fieldDelimiter":"","null_marker":"","preserveAsciiControlCharacters":false,"quote":"","skipLeadingRows":""},"decimalTargetTypes":[],"googleSheetsOptions":{"range":"","skipLeadingRows":""},"hivePartitioningOptions":{"mode":"","requirePartitionFilter":false,"sourceUriPrefix":""},"ignoreUnknownValues":false,"maxBadRecords":0,"metadataCacheMode":"","objectMetadata":"","parquetOptions":{"enableListInference":false,"enumAsString":false},"referenceFileSchemaUri":"","schema":{"fields":[{"categories":{"names":[]},"collation":"","defaultValueExpression":"","description":"","fields":[],"maxLength":"","mode":"","name":"","policyTags":{"names":[]},"precision":"","roundingMode":"","scale":"","type":""}]},"sourceFormat":"","sourceUris":[]},"friendlyName":"","id":"","kind":"","labels":{},"lastModifiedTime":"","location":"","materializedView":{"allow_non_incremental_definition":false,"enableRefresh":false,"lastRefreshTime":"","maxStaleness":"","query":"","refreshIntervalMs":""},"maxStaleness":"","model":{"modelOptions":{"labels":[],"lossType":"","modelType":""},"trainingRuns":[{"iterationResults":[{"durationMs":"","evalLoss":"","index":0,"learnRate":"","trainingLoss":""}],"startTime":"","state":"","trainingOptions":{"earlyStop":false,"l1Reg":"","l2Reg":"","learnRate":"","learnRateStrategy":"","lineSearchInitLearnRate":"","maxIteration":"","minRelProgress":"","warmStart":false}}]},"numBytes":"","numLongTermBytes":"","numPhysicalBytes":"","numRows":"","num_active_logical_bytes":"","num_active_physical_bytes":"","num_long_term_logical_bytes":"","num_long_term_physical_bytes":"","num_partitions":"","num_time_travel_physical_bytes":"","num_total_logical_bytes":"","num_total_physical_bytes":"","rangePartitioning":{"field":"","range":{"end":"","interval":"","start":""}},"requirePartitionFilter":false,"schema":{},"selfLink":"","snapshotDefinition":{"baseTableReference":{},"snapshotTime":""},"streamingBuffer":{"estimatedBytes":"","estimatedRows":"","oldestEntryTime":""},"tableReference":{},"timePartitioning":{"expirationMs":"","field":"","requirePartitionFilter":false,"type":""},"type":"","view":{"query":"","useExplicitColumnNames":false,"useLegacySql":false,"userDefinedFunctionResources":[{"inlineCode":"","resourceUri":""}]}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"cloneDefinition": @{ @"baseTableReference": @{ @"datasetId": @"", @"projectId": @"", @"tableId": @"" }, @"cloneTime": @"" },
                              @"clustering": @{ @"fields": @[  ] },
                              @"creationTime": @"",
                              @"defaultCollation": @"",
                              @"defaultRoundingMode": @"",
                              @"description": @"",
                              @"encryptionConfiguration": @{ @"kmsKeyName": @"" },
                              @"etag": @"",
                              @"expirationTime": @"",
                              @"externalDataConfiguration": @{ @"autodetect": @NO, @"avroOptions": @{ @"useAvroLogicalTypes": @NO }, @"bigtableOptions": @{ @"columnFamilies": @[ @{ @"columns": @[ @{ @"encoding": @"", @"fieldName": @"", @"onlyReadLatest": @NO, @"qualifierEncoded": @"", @"qualifierString": @"", @"type": @"" } ], @"encoding": @"", @"familyId": @"", @"onlyReadLatest": @NO, @"type": @"" } ], @"ignoreUnspecifiedColumnFamilies": @NO, @"readRowkeyAsString": @NO }, @"compression": @"", @"connectionId": @"", @"csvOptions": @{ @"allowJaggedRows": @NO, @"allowQuotedNewlines": @NO, @"encoding": @"", @"fieldDelimiter": @"", @"null_marker": @"", @"preserveAsciiControlCharacters": @NO, @"quote": @"", @"skipLeadingRows": @"" }, @"decimalTargetTypes": @[  ], @"googleSheetsOptions": @{ @"range": @"", @"skipLeadingRows": @"" }, @"hivePartitioningOptions": @{ @"mode": @"", @"requirePartitionFilter": @NO, @"sourceUriPrefix": @"" }, @"ignoreUnknownValues": @NO, @"maxBadRecords": @0, @"metadataCacheMode": @"", @"objectMetadata": @"", @"parquetOptions": @{ @"enableListInference": @NO, @"enumAsString": @NO }, @"referenceFileSchemaUri": @"", @"schema": @{ @"fields": @[ @{ @"categories": @{ @"names": @[  ] }, @"collation": @"", @"defaultValueExpression": @"", @"description": @"", @"fields": @[  ], @"maxLength": @"", @"mode": @"", @"name": @"", @"policyTags": @{ @"names": @[  ] }, @"precision": @"", @"roundingMode": @"", @"scale": @"", @"type": @"" } ] }, @"sourceFormat": @"", @"sourceUris": @[  ] },
                              @"friendlyName": @"",
                              @"id": @"",
                              @"kind": @"",
                              @"labels": @{  },
                              @"lastModifiedTime": @"",
                              @"location": @"",
                              @"materializedView": @{ @"allow_non_incremental_definition": @NO, @"enableRefresh": @NO, @"lastRefreshTime": @"", @"maxStaleness": @"", @"query": @"", @"refreshIntervalMs": @"" },
                              @"maxStaleness": @"",
                              @"model": @{ @"modelOptions": @{ @"labels": @[  ], @"lossType": @"", @"modelType": @"" }, @"trainingRuns": @[ @{ @"iterationResults": @[ @{ @"durationMs": @"", @"evalLoss": @"", @"index": @0, @"learnRate": @"", @"trainingLoss": @"" } ], @"startTime": @"", @"state": @"", @"trainingOptions": @{ @"earlyStop": @NO, @"l1Reg": @"", @"l2Reg": @"", @"learnRate": @"", @"learnRateStrategy": @"", @"lineSearchInitLearnRate": @"", @"maxIteration": @"", @"minRelProgress": @"", @"warmStart": @NO } } ] },
                              @"numBytes": @"",
                              @"numLongTermBytes": @"",
                              @"numPhysicalBytes": @"",
                              @"numRows": @"",
                              @"num_active_logical_bytes": @"",
                              @"num_active_physical_bytes": @"",
                              @"num_long_term_logical_bytes": @"",
                              @"num_long_term_physical_bytes": @"",
                              @"num_partitions": @"",
                              @"num_time_travel_physical_bytes": @"",
                              @"num_total_logical_bytes": @"",
                              @"num_total_physical_bytes": @"",
                              @"rangePartitioning": @{ @"field": @"", @"range": @{ @"end": @"", @"interval": @"", @"start": @"" } },
                              @"requirePartitionFilter": @NO,
                              @"schema": @{  },
                              @"selfLink": @"",
                              @"snapshotDefinition": @{ @"baseTableReference": @{  }, @"snapshotTime": @"" },
                              @"streamingBuffer": @{ @"estimatedBytes": @"", @"estimatedRows": @"", @"oldestEntryTime": @"" },
                              @"tableReference": @{  },
                              @"timePartitioning": @{ @"expirationMs": @"", @"field": @"", @"requirePartitionFilter": @NO, @"type": @"" },
                              @"type": @"",
                              @"view": @{ @"query": @"", @"useExplicitColumnNames": @NO, @"useLegacySql": @NO, @"userDefinedFunctionResources": @[ @{ @"inlineCode": @"", @"resourceUri": @"" } ] } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"PUT"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'cloneDefinition' => [
        'baseTableReference' => [
                'datasetId' => '',
                'projectId' => '',
                'tableId' => ''
        ],
        'cloneTime' => ''
    ],
    'clustering' => [
        'fields' => [
                
        ]
    ],
    'creationTime' => '',
    'defaultCollation' => '',
    'defaultRoundingMode' => '',
    'description' => '',
    'encryptionConfiguration' => [
        'kmsKeyName' => ''
    ],
    'etag' => '',
    'expirationTime' => '',
    'externalDataConfiguration' => [
        'autodetect' => null,
        'avroOptions' => [
                'useAvroLogicalTypes' => null
        ],
        'bigtableOptions' => [
                'columnFamilies' => [
                                [
                                                                'columns' => [
                                                                                                                                [
                                                                                                                                                                                                                                                                'encoding' => '',
                                                                                                                                                                                                                                                                'fieldName' => '',
                                                                                                                                                                                                                                                                'onlyReadLatest' => null,
                                                                                                                                                                                                                                                                'qualifierEncoded' => '',
                                                                                                                                                                                                                                                                'qualifierString' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ]
                                                                ],
                                                                'encoding' => '',
                                                                'familyId' => '',
                                                                'onlyReadLatest' => null,
                                                                'type' => ''
                                ]
                ],
                'ignoreUnspecifiedColumnFamilies' => null,
                'readRowkeyAsString' => null
        ],
        'compression' => '',
        'connectionId' => '',
        'csvOptions' => [
                'allowJaggedRows' => null,
                'allowQuotedNewlines' => null,
                'encoding' => '',
                'fieldDelimiter' => '',
                'null_marker' => '',
                'preserveAsciiControlCharacters' => null,
                'quote' => '',
                'skipLeadingRows' => ''
        ],
        'decimalTargetTypes' => [
                
        ],
        'googleSheetsOptions' => [
                'range' => '',
                'skipLeadingRows' => ''
        ],
        'hivePartitioningOptions' => [
                'mode' => '',
                'requirePartitionFilter' => null,
                'sourceUriPrefix' => ''
        ],
        'ignoreUnknownValues' => null,
        'maxBadRecords' => 0,
        'metadataCacheMode' => '',
        'objectMetadata' => '',
        'parquetOptions' => [
                'enableListInference' => null,
                'enumAsString' => null
        ],
        'referenceFileSchemaUri' => '',
        'schema' => [
                'fields' => [
                                [
                                                                'categories' => [
                                                                                                                                'names' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'collation' => '',
                                                                'defaultValueExpression' => '',
                                                                'description' => '',
                                                                'fields' => [
                                                                                                                                
                                                                ],
                                                                'maxLength' => '',
                                                                'mode' => '',
                                                                'name' => '',
                                                                'policyTags' => [
                                                                                                                                'names' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ]
                                                                ],
                                                                'precision' => '',
                                                                'roundingMode' => '',
                                                                'scale' => '',
                                                                'type' => ''
                                ]
                ]
        ],
        'sourceFormat' => '',
        'sourceUris' => [
                
        ]
    ],
    'friendlyName' => '',
    'id' => '',
    'kind' => '',
    'labels' => [
        
    ],
    'lastModifiedTime' => '',
    'location' => '',
    'materializedView' => [
        'allow_non_incremental_definition' => null,
        'enableRefresh' => null,
        'lastRefreshTime' => '',
        'maxStaleness' => '',
        'query' => '',
        'refreshIntervalMs' => ''
    ],
    'maxStaleness' => '',
    'model' => [
        'modelOptions' => [
                'labels' => [
                                
                ],
                'lossType' => '',
                'modelType' => ''
        ],
        'trainingRuns' => [
                [
                                'iterationResults' => [
                                                                [
                                                                                                                                'durationMs' => '',
                                                                                                                                'evalLoss' => '',
                                                                                                                                'index' => 0,
                                                                                                                                'learnRate' => '',
                                                                                                                                'trainingLoss' => ''
                                                                ]
                                ],
                                'startTime' => '',
                                'state' => '',
                                'trainingOptions' => [
                                                                'earlyStop' => null,
                                                                'l1Reg' => '',
                                                                'l2Reg' => '',
                                                                'learnRate' => '',
                                                                'learnRateStrategy' => '',
                                                                'lineSearchInitLearnRate' => '',
                                                                'maxIteration' => '',
                                                                'minRelProgress' => '',
                                                                'warmStart' => null
                                ]
                ]
        ]
    ],
    'numBytes' => '',
    'numLongTermBytes' => '',
    'numPhysicalBytes' => '',
    'numRows' => '',
    'num_active_logical_bytes' => '',
    'num_active_physical_bytes' => '',
    'num_long_term_logical_bytes' => '',
    'num_long_term_physical_bytes' => '',
    'num_partitions' => '',
    'num_time_travel_physical_bytes' => '',
    'num_total_logical_bytes' => '',
    'num_total_physical_bytes' => '',
    'rangePartitioning' => [
        'field' => '',
        'range' => [
                'end' => '',
                'interval' => '',
                'start' => ''
        ]
    ],
    'requirePartitionFilter' => null,
    'schema' => [
        
    ],
    'selfLink' => '',
    'snapshotDefinition' => [
        'baseTableReference' => [
                
        ],
        'snapshotTime' => ''
    ],
    'streamingBuffer' => [
        'estimatedBytes' => '',
        'estimatedRows' => '',
        'oldestEntryTime' => ''
    ],
    'tableReference' => [
        
    ],
    'timePartitioning' => [
        'expirationMs' => '',
        'field' => '',
        'requirePartitionFilter' => null,
        'type' => ''
    ],
    'type' => '',
    'view' => [
        'query' => '',
        'useExplicitColumnNames' => null,
        'useLegacySql' => null,
        'userDefinedFunctionResources' => [
                [
                                'inlineCode' => '',
                                'resourceUri' => ''
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId', [
  'body' => '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cloneDefinition' => [
    'baseTableReference' => [
        'datasetId' => '',
        'projectId' => '',
        'tableId' => ''
    ],
    'cloneTime' => ''
  ],
  'clustering' => [
    'fields' => [
        
    ]
  ],
  'creationTime' => '',
  'defaultCollation' => '',
  'defaultRoundingMode' => '',
  'description' => '',
  'encryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'etag' => '',
  'expirationTime' => '',
  'externalDataConfiguration' => [
    'autodetect' => null,
    'avroOptions' => [
        'useAvroLogicalTypes' => null
    ],
    'bigtableOptions' => [
        'columnFamilies' => [
                [
                                'columns' => [
                                                                [
                                                                                                                                'encoding' => '',
                                                                                                                                'fieldName' => '',
                                                                                                                                'onlyReadLatest' => null,
                                                                                                                                'qualifierEncoded' => '',
                                                                                                                                'qualifierString' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'encoding' => '',
                                'familyId' => '',
                                'onlyReadLatest' => null,
                                'type' => ''
                ]
        ],
        'ignoreUnspecifiedColumnFamilies' => null,
        'readRowkeyAsString' => null
    ],
    'compression' => '',
    'connectionId' => '',
    'csvOptions' => [
        'allowJaggedRows' => null,
        'allowQuotedNewlines' => null,
        'encoding' => '',
        'fieldDelimiter' => '',
        'null_marker' => '',
        'preserveAsciiControlCharacters' => null,
        'quote' => '',
        'skipLeadingRows' => ''
    ],
    'decimalTargetTypes' => [
        
    ],
    'googleSheetsOptions' => [
        'range' => '',
        'skipLeadingRows' => ''
    ],
    'hivePartitioningOptions' => [
        'mode' => '',
        'requirePartitionFilter' => null,
        'sourceUriPrefix' => ''
    ],
    'ignoreUnknownValues' => null,
    'maxBadRecords' => 0,
    'metadataCacheMode' => '',
    'objectMetadata' => '',
    'parquetOptions' => [
        'enableListInference' => null,
        'enumAsString' => null
    ],
    'referenceFileSchemaUri' => '',
    'schema' => [
        'fields' => [
                [
                                'categories' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'collation' => '',
                                'defaultValueExpression' => '',
                                'description' => '',
                                'fields' => [
                                                                
                                ],
                                'maxLength' => '',
                                'mode' => '',
                                'name' => '',
                                'policyTags' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'precision' => '',
                                'roundingMode' => '',
                                'scale' => '',
                                'type' => ''
                ]
        ]
    ],
    'sourceFormat' => '',
    'sourceUris' => [
        
    ]
  ],
  'friendlyName' => '',
  'id' => '',
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'materializedView' => [
    'allow_non_incremental_definition' => null,
    'enableRefresh' => null,
    'lastRefreshTime' => '',
    'maxStaleness' => '',
    'query' => '',
    'refreshIntervalMs' => ''
  ],
  'maxStaleness' => '',
  'model' => [
    'modelOptions' => [
        'labels' => [
                
        ],
        'lossType' => '',
        'modelType' => ''
    ],
    'trainingRuns' => [
        [
                'iterationResults' => [
                                [
                                                                'durationMs' => '',
                                                                'evalLoss' => '',
                                                                'index' => 0,
                                                                'learnRate' => '',
                                                                'trainingLoss' => ''
                                ]
                ],
                'startTime' => '',
                'state' => '',
                'trainingOptions' => [
                                'earlyStop' => null,
                                'l1Reg' => '',
                                'l2Reg' => '',
                                'learnRate' => '',
                                'learnRateStrategy' => '',
                                'lineSearchInitLearnRate' => '',
                                'maxIteration' => '',
                                'minRelProgress' => '',
                                'warmStart' => null
                ]
        ]
    ]
  ],
  'numBytes' => '',
  'numLongTermBytes' => '',
  'numPhysicalBytes' => '',
  'numRows' => '',
  'num_active_logical_bytes' => '',
  'num_active_physical_bytes' => '',
  'num_long_term_logical_bytes' => '',
  'num_long_term_physical_bytes' => '',
  'num_partitions' => '',
  'num_time_travel_physical_bytes' => '',
  'num_total_logical_bytes' => '',
  'num_total_physical_bytes' => '',
  'rangePartitioning' => [
    'field' => '',
    'range' => [
        'end' => '',
        'interval' => '',
        'start' => ''
    ]
  ],
  'requirePartitionFilter' => null,
  'schema' => [
    
  ],
  'selfLink' => '',
  'snapshotDefinition' => [
    'baseTableReference' => [
        
    ],
    'snapshotTime' => ''
  ],
  'streamingBuffer' => [
    'estimatedBytes' => '',
    'estimatedRows' => '',
    'oldestEntryTime' => ''
  ],
  'tableReference' => [
    
  ],
  'timePartitioning' => [
    'expirationMs' => '',
    'field' => '',
    'requirePartitionFilter' => null,
    'type' => ''
  ],
  'type' => '',
  'view' => [
    'query' => '',
    'useExplicitColumnNames' => null,
    'useLegacySql' => null,
    'userDefinedFunctionResources' => [
        [
                'inlineCode' => '',
                'resourceUri' => ''
        ]
    ]
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cloneDefinition' => [
    'baseTableReference' => [
        'datasetId' => '',
        'projectId' => '',
        'tableId' => ''
    ],
    'cloneTime' => ''
  ],
  'clustering' => [
    'fields' => [
        
    ]
  ],
  'creationTime' => '',
  'defaultCollation' => '',
  'defaultRoundingMode' => '',
  'description' => '',
  'encryptionConfiguration' => [
    'kmsKeyName' => ''
  ],
  'etag' => '',
  'expirationTime' => '',
  'externalDataConfiguration' => [
    'autodetect' => null,
    'avroOptions' => [
        'useAvroLogicalTypes' => null
    ],
    'bigtableOptions' => [
        'columnFamilies' => [
                [
                                'columns' => [
                                                                [
                                                                                                                                'encoding' => '',
                                                                                                                                'fieldName' => '',
                                                                                                                                'onlyReadLatest' => null,
                                                                                                                                'qualifierEncoded' => '',
                                                                                                                                'qualifierString' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'encoding' => '',
                                'familyId' => '',
                                'onlyReadLatest' => null,
                                'type' => ''
                ]
        ],
        'ignoreUnspecifiedColumnFamilies' => null,
        'readRowkeyAsString' => null
    ],
    'compression' => '',
    'connectionId' => '',
    'csvOptions' => [
        'allowJaggedRows' => null,
        'allowQuotedNewlines' => null,
        'encoding' => '',
        'fieldDelimiter' => '',
        'null_marker' => '',
        'preserveAsciiControlCharacters' => null,
        'quote' => '',
        'skipLeadingRows' => ''
    ],
    'decimalTargetTypes' => [
        
    ],
    'googleSheetsOptions' => [
        'range' => '',
        'skipLeadingRows' => ''
    ],
    'hivePartitioningOptions' => [
        'mode' => '',
        'requirePartitionFilter' => null,
        'sourceUriPrefix' => ''
    ],
    'ignoreUnknownValues' => null,
    'maxBadRecords' => 0,
    'metadataCacheMode' => '',
    'objectMetadata' => '',
    'parquetOptions' => [
        'enableListInference' => null,
        'enumAsString' => null
    ],
    'referenceFileSchemaUri' => '',
    'schema' => [
        'fields' => [
                [
                                'categories' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'collation' => '',
                                'defaultValueExpression' => '',
                                'description' => '',
                                'fields' => [
                                                                
                                ],
                                'maxLength' => '',
                                'mode' => '',
                                'name' => '',
                                'policyTags' => [
                                                                'names' => [
                                                                                                                                
                                                                ]
                                ],
                                'precision' => '',
                                'roundingMode' => '',
                                'scale' => '',
                                'type' => ''
                ]
        ]
    ],
    'sourceFormat' => '',
    'sourceUris' => [
        
    ]
  ],
  'friendlyName' => '',
  'id' => '',
  'kind' => '',
  'labels' => [
    
  ],
  'lastModifiedTime' => '',
  'location' => '',
  'materializedView' => [
    'allow_non_incremental_definition' => null,
    'enableRefresh' => null,
    'lastRefreshTime' => '',
    'maxStaleness' => '',
    'query' => '',
    'refreshIntervalMs' => ''
  ],
  'maxStaleness' => '',
  'model' => [
    'modelOptions' => [
        'labels' => [
                
        ],
        'lossType' => '',
        'modelType' => ''
    ],
    'trainingRuns' => [
        [
                'iterationResults' => [
                                [
                                                                'durationMs' => '',
                                                                'evalLoss' => '',
                                                                'index' => 0,
                                                                'learnRate' => '',
                                                                'trainingLoss' => ''
                                ]
                ],
                'startTime' => '',
                'state' => '',
                'trainingOptions' => [
                                'earlyStop' => null,
                                'l1Reg' => '',
                                'l2Reg' => '',
                                'learnRate' => '',
                                'learnRateStrategy' => '',
                                'lineSearchInitLearnRate' => '',
                                'maxIteration' => '',
                                'minRelProgress' => '',
                                'warmStart' => null
                ]
        ]
    ]
  ],
  'numBytes' => '',
  'numLongTermBytes' => '',
  'numPhysicalBytes' => '',
  'numRows' => '',
  'num_active_logical_bytes' => '',
  'num_active_physical_bytes' => '',
  'num_long_term_logical_bytes' => '',
  'num_long_term_physical_bytes' => '',
  'num_partitions' => '',
  'num_time_travel_physical_bytes' => '',
  'num_total_logical_bytes' => '',
  'num_total_physical_bytes' => '',
  'rangePartitioning' => [
    'field' => '',
    'range' => [
        'end' => '',
        'interval' => '',
        'start' => ''
    ]
  ],
  'requirePartitionFilter' => null,
  'schema' => [
    
  ],
  'selfLink' => '',
  'snapshotDefinition' => [
    'baseTableReference' => [
        
    ],
    'snapshotTime' => ''
  ],
  'streamingBuffer' => [
    'estimatedBytes' => '',
    'estimatedRows' => '',
    'oldestEntryTime' => ''
  ],
  'tableReference' => [
    
  ],
  'timePartitioning' => [
    'expirationMs' => '',
    'field' => '',
    'requirePartitionFilter' => null,
    'type' => ''
  ],
  'type' => '',
  'view' => [
    'query' => '',
    'useExplicitColumnNames' => null,
    'useLegacySql' => null,
    'userDefinedFunctionResources' => [
        [
                'inlineCode' => '',
                'resourceUri' => ''
        ]
    ]
  ]
]));
$request->setRequestUrl('{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId');
$request->setRequestMethod('PUT');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

payload = {
    "cloneDefinition": {
        "baseTableReference": {
            "datasetId": "",
            "projectId": "",
            "tableId": ""
        },
        "cloneTime": ""
    },
    "clustering": { "fields": [] },
    "creationTime": "",
    "defaultCollation": "",
    "defaultRoundingMode": "",
    "description": "",
    "encryptionConfiguration": { "kmsKeyName": "" },
    "etag": "",
    "expirationTime": "",
    "externalDataConfiguration": {
        "autodetect": False,
        "avroOptions": { "useAvroLogicalTypes": False },
        "bigtableOptions": {
            "columnFamilies": [
                {
                    "columns": [
                        {
                            "encoding": "",
                            "fieldName": "",
                            "onlyReadLatest": False,
                            "qualifierEncoded": "",
                            "qualifierString": "",
                            "type": ""
                        }
                    ],
                    "encoding": "",
                    "familyId": "",
                    "onlyReadLatest": False,
                    "type": ""
                }
            ],
            "ignoreUnspecifiedColumnFamilies": False,
            "readRowkeyAsString": False
        },
        "compression": "",
        "connectionId": "",
        "csvOptions": {
            "allowJaggedRows": False,
            "allowQuotedNewlines": False,
            "encoding": "",
            "fieldDelimiter": "",
            "null_marker": "",
            "preserveAsciiControlCharacters": False,
            "quote": "",
            "skipLeadingRows": ""
        },
        "decimalTargetTypes": [],
        "googleSheetsOptions": {
            "range": "",
            "skipLeadingRows": ""
        },
        "hivePartitioningOptions": {
            "mode": "",
            "requirePartitionFilter": False,
            "sourceUriPrefix": ""
        },
        "ignoreUnknownValues": False,
        "maxBadRecords": 0,
        "metadataCacheMode": "",
        "objectMetadata": "",
        "parquetOptions": {
            "enableListInference": False,
            "enumAsString": False
        },
        "referenceFileSchemaUri": "",
        "schema": { "fields": [
                {
                    "categories": { "names": [] },
                    "collation": "",
                    "defaultValueExpression": "",
                    "description": "",
                    "fields": [],
                    "maxLength": "",
                    "mode": "",
                    "name": "",
                    "policyTags": { "names": [] },
                    "precision": "",
                    "roundingMode": "",
                    "scale": "",
                    "type": ""
                }
            ] },
        "sourceFormat": "",
        "sourceUris": []
    },
    "friendlyName": "",
    "id": "",
    "kind": "",
    "labels": {},
    "lastModifiedTime": "",
    "location": "",
    "materializedView": {
        "allow_non_incremental_definition": False,
        "enableRefresh": False,
        "lastRefreshTime": "",
        "maxStaleness": "",
        "query": "",
        "refreshIntervalMs": ""
    },
    "maxStaleness": "",
    "model": {
        "modelOptions": {
            "labels": [],
            "lossType": "",
            "modelType": ""
        },
        "trainingRuns": [
            {
                "iterationResults": [
                    {
                        "durationMs": "",
                        "evalLoss": "",
                        "index": 0,
                        "learnRate": "",
                        "trainingLoss": ""
                    }
                ],
                "startTime": "",
                "state": "",
                "trainingOptions": {
                    "earlyStop": False,
                    "l1Reg": "",
                    "l2Reg": "",
                    "learnRate": "",
                    "learnRateStrategy": "",
                    "lineSearchInitLearnRate": "",
                    "maxIteration": "",
                    "minRelProgress": "",
                    "warmStart": False
                }
            }
        ]
    },
    "numBytes": "",
    "numLongTermBytes": "",
    "numPhysicalBytes": "",
    "numRows": "",
    "num_active_logical_bytes": "",
    "num_active_physical_bytes": "",
    "num_long_term_logical_bytes": "",
    "num_long_term_physical_bytes": "",
    "num_partitions": "",
    "num_time_travel_physical_bytes": "",
    "num_total_logical_bytes": "",
    "num_total_physical_bytes": "",
    "rangePartitioning": {
        "field": "",
        "range": {
            "end": "",
            "interval": "",
            "start": ""
        }
    },
    "requirePartitionFilter": False,
    "schema": {},
    "selfLink": "",
    "snapshotDefinition": {
        "baseTableReference": {},
        "snapshotTime": ""
    },
    "streamingBuffer": {
        "estimatedBytes": "",
        "estimatedRows": "",
        "oldestEntryTime": ""
    },
    "tableReference": {},
    "timePartitioning": {
        "expirationMs": "",
        "field": "",
        "requirePartitionFilter": False,
        "type": ""
    },
    "type": "",
    "view": {
        "query": "",
        "useExplicitColumnNames": False,
        "useLegacySql": False,
        "userDefinedFunctionResources": [
            {
                "inlineCode": "",
                "resourceUri": ""
            }
        ]
    }
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId"

payload <- "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}"

encode <- "json"

response <- VERB("PUT", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.put('/baseUrl/projects/:projectId/datasets/:datasetId/tables/:tableId') do |req|
  req.body = "{\n  \"cloneDefinition\": {\n    \"baseTableReference\": {\n      \"datasetId\": \"\",\n      \"projectId\": \"\",\n      \"tableId\": \"\"\n    },\n    \"cloneTime\": \"\"\n  },\n  \"clustering\": {\n    \"fields\": []\n  },\n  \"creationTime\": \"\",\n  \"defaultCollation\": \"\",\n  \"defaultRoundingMode\": \"\",\n  \"description\": \"\",\n  \"encryptionConfiguration\": {\n    \"kmsKeyName\": \"\"\n  },\n  \"etag\": \"\",\n  \"expirationTime\": \"\",\n  \"externalDataConfiguration\": {\n    \"autodetect\": false,\n    \"avroOptions\": {\n      \"useAvroLogicalTypes\": false\n    },\n    \"bigtableOptions\": {\n      \"columnFamilies\": [\n        {\n          \"columns\": [\n            {\n              \"encoding\": \"\",\n              \"fieldName\": \"\",\n              \"onlyReadLatest\": false,\n              \"qualifierEncoded\": \"\",\n              \"qualifierString\": \"\",\n              \"type\": \"\"\n            }\n          ],\n          \"encoding\": \"\",\n          \"familyId\": \"\",\n          \"onlyReadLatest\": false,\n          \"type\": \"\"\n        }\n      ],\n      \"ignoreUnspecifiedColumnFamilies\": false,\n      \"readRowkeyAsString\": false\n    },\n    \"compression\": \"\",\n    \"connectionId\": \"\",\n    \"csvOptions\": {\n      \"allowJaggedRows\": false,\n      \"allowQuotedNewlines\": false,\n      \"encoding\": \"\",\n      \"fieldDelimiter\": \"\",\n      \"null_marker\": \"\",\n      \"preserveAsciiControlCharacters\": false,\n      \"quote\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"decimalTargetTypes\": [],\n    \"googleSheetsOptions\": {\n      \"range\": \"\",\n      \"skipLeadingRows\": \"\"\n    },\n    \"hivePartitioningOptions\": {\n      \"mode\": \"\",\n      \"requirePartitionFilter\": false,\n      \"sourceUriPrefix\": \"\"\n    },\n    \"ignoreUnknownValues\": false,\n    \"maxBadRecords\": 0,\n    \"metadataCacheMode\": \"\",\n    \"objectMetadata\": \"\",\n    \"parquetOptions\": {\n      \"enableListInference\": false,\n      \"enumAsString\": false\n    },\n    \"referenceFileSchemaUri\": \"\",\n    \"schema\": {\n      \"fields\": [\n        {\n          \"categories\": {\n            \"names\": []\n          },\n          \"collation\": \"\",\n          \"defaultValueExpression\": \"\",\n          \"description\": \"\",\n          \"fields\": [],\n          \"maxLength\": \"\",\n          \"mode\": \"\",\n          \"name\": \"\",\n          \"policyTags\": {\n            \"names\": []\n          },\n          \"precision\": \"\",\n          \"roundingMode\": \"\",\n          \"scale\": \"\",\n          \"type\": \"\"\n        }\n      ]\n    },\n    \"sourceFormat\": \"\",\n    \"sourceUris\": []\n  },\n  \"friendlyName\": \"\",\n  \"id\": \"\",\n  \"kind\": \"\",\n  \"labels\": {},\n  \"lastModifiedTime\": \"\",\n  \"location\": \"\",\n  \"materializedView\": {\n    \"allow_non_incremental_definition\": false,\n    \"enableRefresh\": false,\n    \"lastRefreshTime\": \"\",\n    \"maxStaleness\": \"\",\n    \"query\": \"\",\n    \"refreshIntervalMs\": \"\"\n  },\n  \"maxStaleness\": \"\",\n  \"model\": {\n    \"modelOptions\": {\n      \"labels\": [],\n      \"lossType\": \"\",\n      \"modelType\": \"\"\n    },\n    \"trainingRuns\": [\n      {\n        \"iterationResults\": [\n          {\n            \"durationMs\": \"\",\n            \"evalLoss\": \"\",\n            \"index\": 0,\n            \"learnRate\": \"\",\n            \"trainingLoss\": \"\"\n          }\n        ],\n        \"startTime\": \"\",\n        \"state\": \"\",\n        \"trainingOptions\": {\n          \"earlyStop\": false,\n          \"l1Reg\": \"\",\n          \"l2Reg\": \"\",\n          \"learnRate\": \"\",\n          \"learnRateStrategy\": \"\",\n          \"lineSearchInitLearnRate\": \"\",\n          \"maxIteration\": \"\",\n          \"minRelProgress\": \"\",\n          \"warmStart\": false\n        }\n      }\n    ]\n  },\n  \"numBytes\": \"\",\n  \"numLongTermBytes\": \"\",\n  \"numPhysicalBytes\": \"\",\n  \"numRows\": \"\",\n  \"num_active_logical_bytes\": \"\",\n  \"num_active_physical_bytes\": \"\",\n  \"num_long_term_logical_bytes\": \"\",\n  \"num_long_term_physical_bytes\": \"\",\n  \"num_partitions\": \"\",\n  \"num_time_travel_physical_bytes\": \"\",\n  \"num_total_logical_bytes\": \"\",\n  \"num_total_physical_bytes\": \"\",\n  \"rangePartitioning\": {\n    \"field\": \"\",\n    \"range\": {\n      \"end\": \"\",\n      \"interval\": \"\",\n      \"start\": \"\"\n    }\n  },\n  \"requirePartitionFilter\": false,\n  \"schema\": {},\n  \"selfLink\": \"\",\n  \"snapshotDefinition\": {\n    \"baseTableReference\": {},\n    \"snapshotTime\": \"\"\n  },\n  \"streamingBuffer\": {\n    \"estimatedBytes\": \"\",\n    \"estimatedRows\": \"\",\n    \"oldestEntryTime\": \"\"\n  },\n  \"tableReference\": {},\n  \"timePartitioning\": {\n    \"expirationMs\": \"\",\n    \"field\": \"\",\n    \"requirePartitionFilter\": false,\n    \"type\": \"\"\n  },\n  \"type\": \"\",\n  \"view\": {\n    \"query\": \"\",\n    \"useExplicitColumnNames\": false,\n    \"useLegacySql\": false,\n    \"userDefinedFunctionResources\": [\n      {\n        \"inlineCode\": \"\",\n        \"resourceUri\": \"\"\n      }\n    ]\n  }\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId";

    let payload = json!({
        "cloneDefinition": json!({
            "baseTableReference": json!({
                "datasetId": "",
                "projectId": "",
                "tableId": ""
            }),
            "cloneTime": ""
        }),
        "clustering": json!({"fields": ()}),
        "creationTime": "",
        "defaultCollation": "",
        "defaultRoundingMode": "",
        "description": "",
        "encryptionConfiguration": json!({"kmsKeyName": ""}),
        "etag": "",
        "expirationTime": "",
        "externalDataConfiguration": json!({
            "autodetect": false,
            "avroOptions": json!({"useAvroLogicalTypes": false}),
            "bigtableOptions": json!({
                "columnFamilies": (
                    json!({
                        "columns": (
                            json!({
                                "encoding": "",
                                "fieldName": "",
                                "onlyReadLatest": false,
                                "qualifierEncoded": "",
                                "qualifierString": "",
                                "type": ""
                            })
                        ),
                        "encoding": "",
                        "familyId": "",
                        "onlyReadLatest": false,
                        "type": ""
                    })
                ),
                "ignoreUnspecifiedColumnFamilies": false,
                "readRowkeyAsString": false
            }),
            "compression": "",
            "connectionId": "",
            "csvOptions": json!({
                "allowJaggedRows": false,
                "allowQuotedNewlines": false,
                "encoding": "",
                "fieldDelimiter": "",
                "null_marker": "",
                "preserveAsciiControlCharacters": false,
                "quote": "",
                "skipLeadingRows": ""
            }),
            "decimalTargetTypes": (),
            "googleSheetsOptions": json!({
                "range": "",
                "skipLeadingRows": ""
            }),
            "hivePartitioningOptions": json!({
                "mode": "",
                "requirePartitionFilter": false,
                "sourceUriPrefix": ""
            }),
            "ignoreUnknownValues": false,
            "maxBadRecords": 0,
            "metadataCacheMode": "",
            "objectMetadata": "",
            "parquetOptions": json!({
                "enableListInference": false,
                "enumAsString": false
            }),
            "referenceFileSchemaUri": "",
            "schema": json!({"fields": (
                    json!({
                        "categories": json!({"names": ()}),
                        "collation": "",
                        "defaultValueExpression": "",
                        "description": "",
                        "fields": (),
                        "maxLength": "",
                        "mode": "",
                        "name": "",
                        "policyTags": json!({"names": ()}),
                        "precision": "",
                        "roundingMode": "",
                        "scale": "",
                        "type": ""
                    })
                )}),
            "sourceFormat": "",
            "sourceUris": ()
        }),
        "friendlyName": "",
        "id": "",
        "kind": "",
        "labels": json!({}),
        "lastModifiedTime": "",
        "location": "",
        "materializedView": json!({
            "allow_non_incremental_definition": false,
            "enableRefresh": false,
            "lastRefreshTime": "",
            "maxStaleness": "",
            "query": "",
            "refreshIntervalMs": ""
        }),
        "maxStaleness": "",
        "model": json!({
            "modelOptions": json!({
                "labels": (),
                "lossType": "",
                "modelType": ""
            }),
            "trainingRuns": (
                json!({
                    "iterationResults": (
                        json!({
                            "durationMs": "",
                            "evalLoss": "",
                            "index": 0,
                            "learnRate": "",
                            "trainingLoss": ""
                        })
                    ),
                    "startTime": "",
                    "state": "",
                    "trainingOptions": json!({
                        "earlyStop": false,
                        "l1Reg": "",
                        "l2Reg": "",
                        "learnRate": "",
                        "learnRateStrategy": "",
                        "lineSearchInitLearnRate": "",
                        "maxIteration": "",
                        "minRelProgress": "",
                        "warmStart": false
                    })
                })
            )
        }),
        "numBytes": "",
        "numLongTermBytes": "",
        "numPhysicalBytes": "",
        "numRows": "",
        "num_active_logical_bytes": "",
        "num_active_physical_bytes": "",
        "num_long_term_logical_bytes": "",
        "num_long_term_physical_bytes": "",
        "num_partitions": "",
        "num_time_travel_physical_bytes": "",
        "num_total_logical_bytes": "",
        "num_total_physical_bytes": "",
        "rangePartitioning": json!({
            "field": "",
            "range": json!({
                "end": "",
                "interval": "",
                "start": ""
            })
        }),
        "requirePartitionFilter": false,
        "schema": json!({}),
        "selfLink": "",
        "snapshotDefinition": json!({
            "baseTableReference": json!({}),
            "snapshotTime": ""
        }),
        "streamingBuffer": json!({
            "estimatedBytes": "",
            "estimatedRows": "",
            "oldestEntryTime": ""
        }),
        "tableReference": json!({}),
        "timePartitioning": json!({
            "expirationMs": "",
            "field": "",
            "requirePartitionFilter": false,
            "type": ""
        }),
        "type": "",
        "view": json!({
            "query": "",
            "useExplicitColumnNames": false,
            "useLegacySql": false,
            "userDefinedFunctionResources": (
                json!({
                    "inlineCode": "",
                    "resourceUri": ""
                })
            )
        })
    });

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.request(reqwest::Method::from_str("PUT").unwrap(), url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId \
  --header 'content-type: application/json' \
  --data '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}'
echo '{
  "cloneDefinition": {
    "baseTableReference": {
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    },
    "cloneTime": ""
  },
  "clustering": {
    "fields": []
  },
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": {
    "kmsKeyName": ""
  },
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": {
    "autodetect": false,
    "avroOptions": {
      "useAvroLogicalTypes": false
    },
    "bigtableOptions": {
      "columnFamilies": [
        {
          "columns": [
            {
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            }
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        }
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    },
    "compression": "",
    "connectionId": "",
    "csvOptions": {
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    },
    "decimalTargetTypes": [],
    "googleSheetsOptions": {
      "range": "",
      "skipLeadingRows": ""
    },
    "hivePartitioningOptions": {
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    },
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": {
      "enableListInference": false,
      "enumAsString": false
    },
    "referenceFileSchemaUri": "",
    "schema": {
      "fields": [
        {
          "categories": {
            "names": []
          },
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": {
            "names": []
          },
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        }
      ]
    },
    "sourceFormat": "",
    "sourceUris": []
  },
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": {},
  "lastModifiedTime": "",
  "location": "",
  "materializedView": {
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  },
  "maxStaleness": "",
  "model": {
    "modelOptions": {
      "labels": [],
      "lossType": "",
      "modelType": ""
    },
    "trainingRuns": [
      {
        "iterationResults": [
          {
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          }
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": {
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        }
      }
    ]
  },
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": {
    "field": "",
    "range": {
      "end": "",
      "interval": "",
      "start": ""
    }
  },
  "requirePartitionFilter": false,
  "schema": {},
  "selfLink": "",
  "snapshotDefinition": {
    "baseTableReference": {},
    "snapshotTime": ""
  },
  "streamingBuffer": {
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  },
  "tableReference": {},
  "timePartitioning": {
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  },
  "type": "",
  "view": {
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      {
        "inlineCode": "",
        "resourceUri": ""
      }
    ]
  }
}' |  \
  http PUT {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "cloneDefinition": {\n    "baseTableReference": {\n      "datasetId": "",\n      "projectId": "",\n      "tableId": ""\n    },\n    "cloneTime": ""\n  },\n  "clustering": {\n    "fields": []\n  },\n  "creationTime": "",\n  "defaultCollation": "",\n  "defaultRoundingMode": "",\n  "description": "",\n  "encryptionConfiguration": {\n    "kmsKeyName": ""\n  },\n  "etag": "",\n  "expirationTime": "",\n  "externalDataConfiguration": {\n    "autodetect": false,\n    "avroOptions": {\n      "useAvroLogicalTypes": false\n    },\n    "bigtableOptions": {\n      "columnFamilies": [\n        {\n          "columns": [\n            {\n              "encoding": "",\n              "fieldName": "",\n              "onlyReadLatest": false,\n              "qualifierEncoded": "",\n              "qualifierString": "",\n              "type": ""\n            }\n          ],\n          "encoding": "",\n          "familyId": "",\n          "onlyReadLatest": false,\n          "type": ""\n        }\n      ],\n      "ignoreUnspecifiedColumnFamilies": false,\n      "readRowkeyAsString": false\n    },\n    "compression": "",\n    "connectionId": "",\n    "csvOptions": {\n      "allowJaggedRows": false,\n      "allowQuotedNewlines": false,\n      "encoding": "",\n      "fieldDelimiter": "",\n      "null_marker": "",\n      "preserveAsciiControlCharacters": false,\n      "quote": "",\n      "skipLeadingRows": ""\n    },\n    "decimalTargetTypes": [],\n    "googleSheetsOptions": {\n      "range": "",\n      "skipLeadingRows": ""\n    },\n    "hivePartitioningOptions": {\n      "mode": "",\n      "requirePartitionFilter": false,\n      "sourceUriPrefix": ""\n    },\n    "ignoreUnknownValues": false,\n    "maxBadRecords": 0,\n    "metadataCacheMode": "",\n    "objectMetadata": "",\n    "parquetOptions": {\n      "enableListInference": false,\n      "enumAsString": false\n    },\n    "referenceFileSchemaUri": "",\n    "schema": {\n      "fields": [\n        {\n          "categories": {\n            "names": []\n          },\n          "collation": "",\n          "defaultValueExpression": "",\n          "description": "",\n          "fields": [],\n          "maxLength": "",\n          "mode": "",\n          "name": "",\n          "policyTags": {\n            "names": []\n          },\n          "precision": "",\n          "roundingMode": "",\n          "scale": "",\n          "type": ""\n        }\n      ]\n    },\n    "sourceFormat": "",\n    "sourceUris": []\n  },\n  "friendlyName": "",\n  "id": "",\n  "kind": "",\n  "labels": {},\n  "lastModifiedTime": "",\n  "location": "",\n  "materializedView": {\n    "allow_non_incremental_definition": false,\n    "enableRefresh": false,\n    "lastRefreshTime": "",\n    "maxStaleness": "",\n    "query": "",\n    "refreshIntervalMs": ""\n  },\n  "maxStaleness": "",\n  "model": {\n    "modelOptions": {\n      "labels": [],\n      "lossType": "",\n      "modelType": ""\n    },\n    "trainingRuns": [\n      {\n        "iterationResults": [\n          {\n            "durationMs": "",\n            "evalLoss": "",\n            "index": 0,\n            "learnRate": "",\n            "trainingLoss": ""\n          }\n        ],\n        "startTime": "",\n        "state": "",\n        "trainingOptions": {\n          "earlyStop": false,\n          "l1Reg": "",\n          "l2Reg": "",\n          "learnRate": "",\n          "learnRateStrategy": "",\n          "lineSearchInitLearnRate": "",\n          "maxIteration": "",\n          "minRelProgress": "",\n          "warmStart": false\n        }\n      }\n    ]\n  },\n  "numBytes": "",\n  "numLongTermBytes": "",\n  "numPhysicalBytes": "",\n  "numRows": "",\n  "num_active_logical_bytes": "",\n  "num_active_physical_bytes": "",\n  "num_long_term_logical_bytes": "",\n  "num_long_term_physical_bytes": "",\n  "num_partitions": "",\n  "num_time_travel_physical_bytes": "",\n  "num_total_logical_bytes": "",\n  "num_total_physical_bytes": "",\n  "rangePartitioning": {\n    "field": "",\n    "range": {\n      "end": "",\n      "interval": "",\n      "start": ""\n    }\n  },\n  "requirePartitionFilter": false,\n  "schema": {},\n  "selfLink": "",\n  "snapshotDefinition": {\n    "baseTableReference": {},\n    "snapshotTime": ""\n  },\n  "streamingBuffer": {\n    "estimatedBytes": "",\n    "estimatedRows": "",\n    "oldestEntryTime": ""\n  },\n  "tableReference": {},\n  "timePartitioning": {\n    "expirationMs": "",\n    "field": "",\n    "requirePartitionFilter": false,\n    "type": ""\n  },\n  "type": "",\n  "view": {\n    "query": "",\n    "useExplicitColumnNames": false,\n    "useLegacySql": false,\n    "userDefinedFunctionResources": [\n      {\n        "inlineCode": "",\n        "resourceUri": ""\n      }\n    ]\n  }\n}' \
  --output-document \
  - {{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "cloneDefinition": [
    "baseTableReference": [
      "datasetId": "",
      "projectId": "",
      "tableId": ""
    ],
    "cloneTime": ""
  ],
  "clustering": ["fields": []],
  "creationTime": "",
  "defaultCollation": "",
  "defaultRoundingMode": "",
  "description": "",
  "encryptionConfiguration": ["kmsKeyName": ""],
  "etag": "",
  "expirationTime": "",
  "externalDataConfiguration": [
    "autodetect": false,
    "avroOptions": ["useAvroLogicalTypes": false],
    "bigtableOptions": [
      "columnFamilies": [
        [
          "columns": [
            [
              "encoding": "",
              "fieldName": "",
              "onlyReadLatest": false,
              "qualifierEncoded": "",
              "qualifierString": "",
              "type": ""
            ]
          ],
          "encoding": "",
          "familyId": "",
          "onlyReadLatest": false,
          "type": ""
        ]
      ],
      "ignoreUnspecifiedColumnFamilies": false,
      "readRowkeyAsString": false
    ],
    "compression": "",
    "connectionId": "",
    "csvOptions": [
      "allowJaggedRows": false,
      "allowQuotedNewlines": false,
      "encoding": "",
      "fieldDelimiter": "",
      "null_marker": "",
      "preserveAsciiControlCharacters": false,
      "quote": "",
      "skipLeadingRows": ""
    ],
    "decimalTargetTypes": [],
    "googleSheetsOptions": [
      "range": "",
      "skipLeadingRows": ""
    ],
    "hivePartitioningOptions": [
      "mode": "",
      "requirePartitionFilter": false,
      "sourceUriPrefix": ""
    ],
    "ignoreUnknownValues": false,
    "maxBadRecords": 0,
    "metadataCacheMode": "",
    "objectMetadata": "",
    "parquetOptions": [
      "enableListInference": false,
      "enumAsString": false
    ],
    "referenceFileSchemaUri": "",
    "schema": ["fields": [
        [
          "categories": ["names": []],
          "collation": "",
          "defaultValueExpression": "",
          "description": "",
          "fields": [],
          "maxLength": "",
          "mode": "",
          "name": "",
          "policyTags": ["names": []],
          "precision": "",
          "roundingMode": "",
          "scale": "",
          "type": ""
        ]
      ]],
    "sourceFormat": "",
    "sourceUris": []
  ],
  "friendlyName": "",
  "id": "",
  "kind": "",
  "labels": [],
  "lastModifiedTime": "",
  "location": "",
  "materializedView": [
    "allow_non_incremental_definition": false,
    "enableRefresh": false,
    "lastRefreshTime": "",
    "maxStaleness": "",
    "query": "",
    "refreshIntervalMs": ""
  ],
  "maxStaleness": "",
  "model": [
    "modelOptions": [
      "labels": [],
      "lossType": "",
      "modelType": ""
    ],
    "trainingRuns": [
      [
        "iterationResults": [
          [
            "durationMs": "",
            "evalLoss": "",
            "index": 0,
            "learnRate": "",
            "trainingLoss": ""
          ]
        ],
        "startTime": "",
        "state": "",
        "trainingOptions": [
          "earlyStop": false,
          "l1Reg": "",
          "l2Reg": "",
          "learnRate": "",
          "learnRateStrategy": "",
          "lineSearchInitLearnRate": "",
          "maxIteration": "",
          "minRelProgress": "",
          "warmStart": false
        ]
      ]
    ]
  ],
  "numBytes": "",
  "numLongTermBytes": "",
  "numPhysicalBytes": "",
  "numRows": "",
  "num_active_logical_bytes": "",
  "num_active_physical_bytes": "",
  "num_long_term_logical_bytes": "",
  "num_long_term_physical_bytes": "",
  "num_partitions": "",
  "num_time_travel_physical_bytes": "",
  "num_total_logical_bytes": "",
  "num_total_physical_bytes": "",
  "rangePartitioning": [
    "field": "",
    "range": [
      "end": "",
      "interval": "",
      "start": ""
    ]
  ],
  "requirePartitionFilter": false,
  "schema": [],
  "selfLink": "",
  "snapshotDefinition": [
    "baseTableReference": [],
    "snapshotTime": ""
  ],
  "streamingBuffer": [
    "estimatedBytes": "",
    "estimatedRows": "",
    "oldestEntryTime": ""
  ],
  "tableReference": [],
  "timePartitioning": [
    "expirationMs": "",
    "field": "",
    "requirePartitionFilter": false,
    "type": ""
  ],
  "type": "",
  "view": [
    "query": "",
    "useExplicitColumnNames": false,
    "useLegacySql": false,
    "userDefinedFunctionResources": [
      [
        "inlineCode": "",
        "resourceUri": ""
      ]
    ]
  ]
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/projects/:projectId/datasets/:datasetId/tables/:tableId")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "PUT"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()