GET container.projects.aggregated.usableSubnetworks.list
{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks");

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

(client/get "{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks")
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks"

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

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

func main() {

	url := "{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks"

	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/v1beta1/:parent/aggregated/usableSubnetworks HTTP/1.1
Host: example.com

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

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks")
  .get()
  .build()

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

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

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

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

const req = unirest('GET', '{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks');

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}}/v1beta1/:parent/aggregated/usableSubnetworks'
};

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/v1beta1/:parent/aggregated/usableSubnetworks")

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

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

url = "{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks"

response = requests.get(url)

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

url <- "{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks"

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

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

url = URI("{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks")

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/v1beta1/:parent/aggregated/usableSubnetworks') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/aggregated/usableSubnetworks")! 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 container.projects.locations.clusters.completeIpRotation
{{baseUrl}}/v1beta1/:name:completeIpRotation
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:completeIpRotation" {:content-type :json
                                                                             :form-params {:clusterId ""
                                                                                           :name ""
                                                                                           :projectId ""
                                                                                           :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:completeIpRotation"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:completeIpRotation"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:completeIpRotation");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:completeIpRotation"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:completeIpRotation HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 68

{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:completeIpRotation")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:completeIpRotation"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:completeIpRotation")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:completeIpRotation")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  name: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:completeIpRotation',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', projectId: '', zone: ''}
};

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

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}}/v1beta1/:name:completeIpRotation',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:completeIpRotation',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', name: '', projectId: '', zone: ''},
  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}}/v1beta1/:name:completeIpRotation');

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

req.type('json');
req.send({
  clusterId: '',
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:completeIpRotation',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', projectId: '', zone: ''}
};

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

const url = '{{baseUrl}}/v1beta1/:name:completeIpRotation';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

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

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:completeIpRotation",
  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([
    'clusterId' => '',
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:completeIpRotation', [
  'body' => '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

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

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

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

payload = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:completeIpRotation", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:completeIpRotation"

payload = {
    "clusterId": "",
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:completeIpRotation"

payload <- "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:completeIpRotation")

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:completeIpRotation') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:completeIpRotation \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:completeIpRotation \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:completeIpRotation
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:completeIpRotation")! 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 container.projects.locations.clusters.create
{{baseUrl}}/v1beta1/:parent/clusters
QUERY PARAMS

parent
BODY json

{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:parent/clusters" {:content-type :json
                                                                     :form-params {:cluster {:addonsConfig {:cloudRunConfig {:disabled false
                                                                                                                             :loadBalancerType ""}
                                                                                                            :configConnectorConfig {:enabled false}
                                                                                                            :dnsCacheConfig {:enabled false}
                                                                                                            :gcePersistentDiskCsiDriverConfig {:enabled false}
                                                                                                            :gcpFilestoreCsiDriverConfig {:enabled false}
                                                                                                            :gkeBackupAgentConfig {:enabled false}
                                                                                                            :horizontalPodAutoscaling {:disabled false}
                                                                                                            :httpLoadBalancing {:disabled false}
                                                                                                            :istioConfig {:auth ""
                                                                                                                          :disabled false}
                                                                                                            :kalmConfig {:enabled false}
                                                                                                            :kubernetesDashboard {:disabled false}
                                                                                                            :networkPolicyConfig {:disabled false}}
                                                                                             :authenticatorGroupsConfig {:enabled false
                                                                                                                         :securityGroup ""}
                                                                                             :autopilot {:enabled false}
                                                                                             :autoscaling {:autoprovisioningLocations []
                                                                                                           :autoprovisioningNodePoolDefaults {:bootDiskKmsKey ""
                                                                                                                                              :diskSizeGb 0
                                                                                                                                              :diskType ""
                                                                                                                                              :imageType ""
                                                                                                                                              :management {:autoRepair false
                                                                                                                                                           :autoUpgrade false
                                                                                                                                                           :upgradeOptions {:autoUpgradeStartTime ""
                                                                                                                                                                            :description ""}}
                                                                                                                                              :minCpuPlatform ""
                                                                                                                                              :oauthScopes []
                                                                                                                                              :serviceAccount ""
                                                                                                                                              :shieldedInstanceConfig {:enableIntegrityMonitoring false
                                                                                                                                                                       :enableSecureBoot false}
                                                                                                                                              :upgradeSettings {:blueGreenSettings {:nodePoolSoakDuration ""
                                                                                                                                                                                    :standardRolloutPolicy {:batchNodeCount 0
                                                                                                                                                                                                            :batchPercentage ""
                                                                                                                                                                                                            :batchSoakDuration ""}}
                                                                                                                                                                :maxSurge 0
                                                                                                                                                                :maxUnavailable 0
                                                                                                                                                                :strategy ""}}
                                                                                                           :autoscalingProfile ""
                                                                                                           :enableNodeAutoprovisioning false
                                                                                                           :resourceLimits [{:maximum ""
                                                                                                                             :minimum ""
                                                                                                                             :resourceType ""}]}
                                                                                             :binaryAuthorization {:enabled false
                                                                                                                   :evaluationMode ""}
                                                                                             :clusterIpv4Cidr ""
                                                                                             :clusterTelemetry {:type ""}
                                                                                             :conditions [{:canonicalCode ""
                                                                                                           :code ""
                                                                                                           :message ""}]
                                                                                             :confidentialNodes {:enabled false}
                                                                                             :costManagementConfig {:enabled false}
                                                                                             :createTime ""
                                                                                             :currentMasterVersion ""
                                                                                             :currentNodeCount 0
                                                                                             :currentNodeVersion ""
                                                                                             :databaseEncryption {:keyName ""
                                                                                                                  :state ""}
                                                                                             :defaultMaxPodsConstraint {:maxPodsPerNode ""}
                                                                                             :description ""
                                                                                             :enableKubernetesAlpha false
                                                                                             :enableTpu false
                                                                                             :endpoint ""
                                                                                             :etag ""
                                                                                             :expireTime ""
                                                                                             :fleet {:membership ""
                                                                                                     :preRegistered false
                                                                                                     :project ""}
                                                                                             :id ""
                                                                                             :identityServiceConfig {:enabled false}
                                                                                             :initialClusterVersion ""
                                                                                             :initialNodeCount 0
                                                                                             :instanceGroupUrls []
                                                                                             :ipAllocationPolicy {:additionalPodRangesConfig {:podRangeNames []}
                                                                                                                  :allowRouteOverlap false
                                                                                                                  :clusterIpv4Cidr ""
                                                                                                                  :clusterIpv4CidrBlock ""
                                                                                                                  :clusterSecondaryRangeName ""
                                                                                                                  :createSubnetwork false
                                                                                                                  :ipv6AccessType ""
                                                                                                                  :nodeIpv4Cidr ""
                                                                                                                  :nodeIpv4CidrBlock ""
                                                                                                                  :podCidrOverprovisionConfig {:disable false}
                                                                                                                  :servicesIpv4Cidr ""
                                                                                                                  :servicesIpv4CidrBlock ""
                                                                                                                  :servicesIpv6CidrBlock ""
                                                                                                                  :servicesSecondaryRangeName ""
                                                                                                                  :stackType ""
                                                                                                                  :subnetIpv6CidrBlock ""
                                                                                                                  :subnetworkName ""
                                                                                                                  :tpuIpv4CidrBlock ""
                                                                                                                  :useIpAliases false
                                                                                                                  :useRoutes false}
                                                                                             :labelFingerprint ""
                                                                                             :legacyAbac {:enabled false}
                                                                                             :location ""
                                                                                             :locations []
                                                                                             :loggingConfig {:componentConfig {:enableComponents []}}
                                                                                             :loggingService ""
                                                                                             :maintenancePolicy {:resourceVersion ""
                                                                                                                 :window {:dailyMaintenanceWindow {:duration ""
                                                                                                                                                   :startTime ""}
                                                                                                                          :maintenanceExclusions {}
                                                                                                                          :recurringWindow {:recurrence ""
                                                                                                                                            :window {:endTime ""
                                                                                                                                                     :maintenanceExclusionOptions {:scope ""}
                                                                                                                                                     :startTime ""}}}}
                                                                                             :master {}
                                                                                             :masterAuth {:clientCertificate ""
                                                                                                          :clientCertificateConfig {:issueClientCertificate false}
                                                                                                          :clientKey ""
                                                                                                          :clusterCaCertificate ""
                                                                                                          :password ""
                                                                                                          :username ""}
                                                                                             :masterAuthorizedNetworksConfig {:cidrBlocks [{:cidrBlock ""
                                                                                                                                            :displayName ""}]
                                                                                                                              :enabled false
                                                                                                                              :gcpPublicCidrsAccessEnabled false}
                                                                                             :masterIpv4CidrBlock ""
                                                                                             :meshCertificates {:enableCertificates false}
                                                                                             :monitoringConfig {:componentConfig {:enableComponents []}
                                                                                                                :managedPrometheusConfig {:enabled false}}
                                                                                             :monitoringService ""
                                                                                             :name ""
                                                                                             :network ""
                                                                                             :networkConfig {:datapathProvider ""
                                                                                                             :defaultSnatStatus {:disabled false}
                                                                                                             :dnsConfig {:clusterDns ""
                                                                                                                         :clusterDnsDomain ""
                                                                                                                         :clusterDnsScope ""}
                                                                                                             :enableIntraNodeVisibility false
                                                                                                             :enableL4ilbSubsetting false
                                                                                                             :gatewayApiConfig {:channel ""}
                                                                                                             :network ""
                                                                                                             :privateIpv6GoogleAccess ""
                                                                                                             :serviceExternalIpsConfig {:enabled false}
                                                                                                             :subnetwork ""}
                                                                                             :networkPolicy {:enabled false
                                                                                                             :provider ""}
                                                                                             :nodeConfig {:accelerators [{:acceleratorCount ""
                                                                                                                          :acceleratorType ""
                                                                                                                          :gpuPartitionSize ""
                                                                                                                          :gpuSharingConfig {:gpuSharingStrategy ""
                                                                                                                                             :maxSharedClientsPerGpu ""}
                                                                                                                          :maxTimeSharedClientsPerGpu ""}]
                                                                                                          :advancedMachineFeatures {:threadsPerCore ""}
                                                                                                          :bootDiskKmsKey ""
                                                                                                          :confidentialNodes {}
                                                                                                          :diskSizeGb 0
                                                                                                          :diskType ""
                                                                                                          :ephemeralStorageConfig {:localSsdCount 0}
                                                                                                          :ephemeralStorageLocalSsdConfig {:localSsdCount 0}
                                                                                                          :fastSocket {:enabled false}
                                                                                                          :gcfsConfig {:enabled false}
                                                                                                          :gvnic {:enabled false}
                                                                                                          :imageType ""
                                                                                                          :kubeletConfig {:cpuCfsQuota false
                                                                                                                          :cpuCfsQuotaPeriod ""
                                                                                                                          :cpuManagerPolicy ""
                                                                                                                          :podPidsLimit ""}
                                                                                                          :labels {}
                                                                                                          :linuxNodeConfig {:cgroupMode ""
                                                                                                                            :sysctls {}}
                                                                                                          :localNvmeSsdBlockConfig {:localSsdCount 0}
                                                                                                          :localSsdCount 0
                                                                                                          :loggingConfig {:variantConfig {:variant ""}}
                                                                                                          :machineType ""
                                                                                                          :metadata {}
                                                                                                          :minCpuPlatform ""
                                                                                                          :nodeGroup ""
                                                                                                          :oauthScopes []
                                                                                                          :preemptible false
                                                                                                          :reservationAffinity {:consumeReservationType ""
                                                                                                                                :key ""
                                                                                                                                :values []}
                                                                                                          :resourceLabels {}
                                                                                                          :sandboxConfig {:sandboxType ""
                                                                                                                          :type ""}
                                                                                                          :serviceAccount ""
                                                                                                          :shieldedInstanceConfig {}
                                                                                                          :spot false
                                                                                                          :tags []
                                                                                                          :taints [{:effect ""
                                                                                                                    :key ""
                                                                                                                    :value ""}]
                                                                                                          :windowsNodeConfig {:osVersion ""}
                                                                                                          :workloadMetadataConfig {:mode ""
                                                                                                                                   :nodeMetadata ""}}
                                                                                             :nodeIpv4CidrSize 0
                                                                                             :nodePoolAutoConfig {:networkTags {:tags []}}
                                                                                             :nodePoolDefaults {:nodeConfigDefaults {:gcfsConfig {}
                                                                                                                                     :loggingConfig {}}}
                                                                                             :nodePools [{:autoscaling {:autoprovisioned false
                                                                                                                        :enabled false
                                                                                                                        :locationPolicy ""
                                                                                                                        :maxNodeCount 0
                                                                                                                        :minNodeCount 0
                                                                                                                        :totalMaxNodeCount 0
                                                                                                                        :totalMinNodeCount 0}
                                                                                                          :conditions [{}]
                                                                                                          :config {}
                                                                                                          :etag ""
                                                                                                          :initialNodeCount 0
                                                                                                          :instanceGroupUrls []
                                                                                                          :locations []
                                                                                                          :management {}
                                                                                                          :maxPodsConstraint {}
                                                                                                          :name ""
                                                                                                          :networkConfig {:createPodRange false
                                                                                                                          :enablePrivateNodes false
                                                                                                                          :networkPerformanceConfig {:externalIpEgressBandwidthTier ""
                                                                                                                                                     :totalEgressBandwidthTier ""}
                                                                                                                          :podCidrOverprovisionConfig {}
                                                                                                                          :podIpv4CidrBlock ""
                                                                                                                          :podRange ""}
                                                                                                          :placementPolicy {:type ""}
                                                                                                          :podIpv4CidrSize 0
                                                                                                          :selfLink ""
                                                                                                          :status ""
                                                                                                          :statusMessage ""
                                                                                                          :updateInfo {:blueGreenInfo {:blueInstanceGroupUrls []
                                                                                                                                       :bluePoolDeletionStartTime ""
                                                                                                                                       :greenInstanceGroupUrls []
                                                                                                                                       :greenPoolVersion ""
                                                                                                                                       :phase ""}}
                                                                                                          :upgradeSettings {}
                                                                                                          :version ""}]
                                                                                             :notificationConfig {:pubsub {:enabled false
                                                                                                                           :filter {:eventType []}
                                                                                                                           :topic ""}}
                                                                                             :podSecurityPolicyConfig {:enabled false}
                                                                                             :privateCluster false
                                                                                             :privateClusterConfig {:enablePrivateEndpoint false
                                                                                                                    :enablePrivateNodes false
                                                                                                                    :masterGlobalAccessConfig {:enabled false}
                                                                                                                    :masterIpv4CidrBlock ""
                                                                                                                    :peeringName ""
                                                                                                                    :privateEndpoint ""
                                                                                                                    :privateEndpointSubnetwork ""
                                                                                                                    :publicEndpoint ""}
                                                                                             :protectConfig {:workloadConfig {:auditMode ""}
                                                                                                             :workloadVulnerabilityMode ""}
                                                                                             :releaseChannel {:channel ""}
                                                                                             :resourceLabels {}
                                                                                             :resourceUsageExportConfig {:bigqueryDestination {:datasetId ""}
                                                                                                                         :consumptionMeteringConfig {:enabled false}
                                                                                                                         :enableNetworkEgressMetering false}
                                                                                             :selfLink ""
                                                                                             :servicesIpv4Cidr ""
                                                                                             :shieldedNodes {:enabled false}
                                                                                             :status ""
                                                                                             :statusMessage ""
                                                                                             :subnetwork ""
                                                                                             :tpuConfig {:enabled false
                                                                                                         :ipv4CidrBlock ""
                                                                                                         :useServiceNetworking false}
                                                                                             :tpuIpv4CidrBlock ""
                                                                                             :verticalPodAutoscaling {:enabled false}
                                                                                             :workloadAltsConfig {:enableAlts false}
                                                                                             :workloadCertificates {:enableCertificates false}
                                                                                             :workloadIdentityConfig {:identityNamespace ""
                                                                                                                      :identityProvider ""
                                                                                                                      :workloadPool ""}
                                                                                             :zone ""}
                                                                                   :parent ""
                                                                                   :projectId ""
                                                                                   :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/clusters"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:parent/clusters"),
    Content = new StringContent("{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:parent/clusters");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:parent/clusters"

	payload := strings.NewReader("{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:parent/clusters HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 11569

{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:parent/clusters")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:parent/clusters"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/clusters")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:parent/clusters")
  .header("content-type", "application/json")
  .body("{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  cluster: {
    addonsConfig: {
      cloudRunConfig: {
        disabled: false,
        loadBalancerType: ''
      },
      configConnectorConfig: {
        enabled: false
      },
      dnsCacheConfig: {
        enabled: false
      },
      gcePersistentDiskCsiDriverConfig: {
        enabled: false
      },
      gcpFilestoreCsiDriverConfig: {
        enabled: false
      },
      gkeBackupAgentConfig: {
        enabled: false
      },
      horizontalPodAutoscaling: {
        disabled: false
      },
      httpLoadBalancing: {
        disabled: false
      },
      istioConfig: {
        auth: '',
        disabled: false
      },
      kalmConfig: {
        enabled: false
      },
      kubernetesDashboard: {
        disabled: false
      },
      networkPolicyConfig: {
        disabled: false
      }
    },
    authenticatorGroupsConfig: {
      enabled: false,
      securityGroup: ''
    },
    autopilot: {
      enabled: false
    },
    autoscaling: {
      autoprovisioningLocations: [],
      autoprovisioningNodePoolDefaults: {
        bootDiskKmsKey: '',
        diskSizeGb: 0,
        diskType: '',
        imageType: '',
        management: {
          autoRepair: false,
          autoUpgrade: false,
          upgradeOptions: {
            autoUpgradeStartTime: '',
            description: ''
          }
        },
        minCpuPlatform: '',
        oauthScopes: [],
        serviceAccount: '',
        shieldedInstanceConfig: {
          enableIntegrityMonitoring: false,
          enableSecureBoot: false
        },
        upgradeSettings: {
          blueGreenSettings: {
            nodePoolSoakDuration: '',
            standardRolloutPolicy: {
              batchNodeCount: 0,
              batchPercentage: '',
              batchSoakDuration: ''
            }
          },
          maxSurge: 0,
          maxUnavailable: 0,
          strategy: ''
        }
      },
      autoscalingProfile: '',
      enableNodeAutoprovisioning: false,
      resourceLimits: [
        {
          maximum: '',
          minimum: '',
          resourceType: ''
        }
      ]
    },
    binaryAuthorization: {
      enabled: false,
      evaluationMode: ''
    },
    clusterIpv4Cidr: '',
    clusterTelemetry: {
      type: ''
    },
    conditions: [
      {
        canonicalCode: '',
        code: '',
        message: ''
      }
    ],
    confidentialNodes: {
      enabled: false
    },
    costManagementConfig: {
      enabled: false
    },
    createTime: '',
    currentMasterVersion: '',
    currentNodeCount: 0,
    currentNodeVersion: '',
    databaseEncryption: {
      keyName: '',
      state: ''
    },
    defaultMaxPodsConstraint: {
      maxPodsPerNode: ''
    },
    description: '',
    enableKubernetesAlpha: false,
    enableTpu: false,
    endpoint: '',
    etag: '',
    expireTime: '',
    fleet: {
      membership: '',
      preRegistered: false,
      project: ''
    },
    id: '',
    identityServiceConfig: {
      enabled: false
    },
    initialClusterVersion: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    ipAllocationPolicy: {
      additionalPodRangesConfig: {
        podRangeNames: []
      },
      allowRouteOverlap: false,
      clusterIpv4Cidr: '',
      clusterIpv4CidrBlock: '',
      clusterSecondaryRangeName: '',
      createSubnetwork: false,
      ipv6AccessType: '',
      nodeIpv4Cidr: '',
      nodeIpv4CidrBlock: '',
      podCidrOverprovisionConfig: {
        disable: false
      },
      servicesIpv4Cidr: '',
      servicesIpv4CidrBlock: '',
      servicesIpv6CidrBlock: '',
      servicesSecondaryRangeName: '',
      stackType: '',
      subnetIpv6CidrBlock: '',
      subnetworkName: '',
      tpuIpv4CidrBlock: '',
      useIpAliases: false,
      useRoutes: false
    },
    labelFingerprint: '',
    legacyAbac: {
      enabled: false
    },
    location: '',
    locations: [],
    loggingConfig: {
      componentConfig: {
        enableComponents: []
      }
    },
    loggingService: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {
          duration: '',
          startTime: ''
        },
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {
            endTime: '',
            maintenanceExclusionOptions: {
              scope: ''
            },
            startTime: ''
          }
        }
      }
    },
    master: {},
    masterAuth: {
      clientCertificate: '',
      clientCertificateConfig: {
        issueClientCertificate: false
      },
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    masterAuthorizedNetworksConfig: {
      cidrBlocks: [
        {
          cidrBlock: '',
          displayName: ''
        }
      ],
      enabled: false,
      gcpPublicCidrsAccessEnabled: false
    },
    masterIpv4CidrBlock: '',
    meshCertificates: {
      enableCertificates: false
    },
    monitoringConfig: {
      componentConfig: {
        enableComponents: []
      },
      managedPrometheusConfig: {
        enabled: false
      }
    },
    monitoringService: '',
    name: '',
    network: '',
    networkConfig: {
      datapathProvider: '',
      defaultSnatStatus: {
        disabled: false
      },
      dnsConfig: {
        clusterDns: '',
        clusterDnsDomain: '',
        clusterDnsScope: ''
      },
      enableIntraNodeVisibility: false,
      enableL4ilbSubsetting: false,
      gatewayApiConfig: {
        channel: ''
      },
      network: '',
      privateIpv6GoogleAccess: '',
      serviceExternalIpsConfig: {
        enabled: false
      },
      subnetwork: ''
    },
    networkPolicy: {
      enabled: false,
      provider: ''
    },
    nodeConfig: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {
            gpuSharingStrategy: '',
            maxSharedClientsPerGpu: ''
          },
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {
        threadsPerCore: ''
      },
      bootDiskKmsKey: '',
      confidentialNodes: {},
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {
        localSsdCount: 0
      },
      ephemeralStorageLocalSsdConfig: {
        localSsdCount: 0
      },
      fastSocket: {
        enabled: false
      },
      gcfsConfig: {
        enabled: false
      },
      gvnic: {
        enabled: false
      },
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {
        cgroupMode: '',
        sysctls: {}
      },
      localNvmeSsdBlockConfig: {
        localSsdCount: 0
      },
      localSsdCount: 0,
      loggingConfig: {
        variantConfig: {
          variant: ''
        }
      },
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {
        consumeReservationType: '',
        key: '',
        values: []
      },
      resourceLabels: {},
      sandboxConfig: {
        sandboxType: '',
        type: ''
      },
      serviceAccount: '',
      shieldedInstanceConfig: {},
      spot: false,
      tags: [],
      taints: [
        {
          effect: '',
          key: '',
          value: ''
        }
      ],
      windowsNodeConfig: {
        osVersion: ''
      },
      workloadMetadataConfig: {
        mode: '',
        nodeMetadata: ''
      }
    },
    nodeIpv4CidrSize: 0,
    nodePoolAutoConfig: {
      networkTags: {
        tags: []
      }
    },
    nodePoolDefaults: {
      nodeConfigDefaults: {
        gcfsConfig: {},
        loggingConfig: {}
      }
    },
    nodePools: [
      {
        autoscaling: {
          autoprovisioned: false,
          enabled: false,
          locationPolicy: '',
          maxNodeCount: 0,
          minNodeCount: 0,
          totalMaxNodeCount: 0,
          totalMinNodeCount: 0
        },
        conditions: [
          {}
        ],
        config: {},
        etag: '',
        initialNodeCount: 0,
        instanceGroupUrls: [],
        locations: [],
        management: {},
        maxPodsConstraint: {},
        name: '',
        networkConfig: {
          createPodRange: false,
          enablePrivateNodes: false,
          networkPerformanceConfig: {
            externalIpEgressBandwidthTier: '',
            totalEgressBandwidthTier: ''
          },
          podCidrOverprovisionConfig: {},
          podIpv4CidrBlock: '',
          podRange: ''
        },
        placementPolicy: {
          type: ''
        },
        podIpv4CidrSize: 0,
        selfLink: '',
        status: '',
        statusMessage: '',
        updateInfo: {
          blueGreenInfo: {
            blueInstanceGroupUrls: [],
            bluePoolDeletionStartTime: '',
            greenInstanceGroupUrls: [],
            greenPoolVersion: '',
            phase: ''
          }
        },
        upgradeSettings: {},
        version: ''
      }
    ],
    notificationConfig: {
      pubsub: {
        enabled: false,
        filter: {
          eventType: []
        },
        topic: ''
      }
    },
    podSecurityPolicyConfig: {
      enabled: false
    },
    privateCluster: false,
    privateClusterConfig: {
      enablePrivateEndpoint: false,
      enablePrivateNodes: false,
      masterGlobalAccessConfig: {
        enabled: false
      },
      masterIpv4CidrBlock: '',
      peeringName: '',
      privateEndpoint: '',
      privateEndpointSubnetwork: '',
      publicEndpoint: ''
    },
    protectConfig: {
      workloadConfig: {
        auditMode: ''
      },
      workloadVulnerabilityMode: ''
    },
    releaseChannel: {
      channel: ''
    },
    resourceLabels: {},
    resourceUsageExportConfig: {
      bigqueryDestination: {
        datasetId: ''
      },
      consumptionMeteringConfig: {
        enabled: false
      },
      enableNetworkEgressMetering: false
    },
    selfLink: '',
    servicesIpv4Cidr: '',
    shieldedNodes: {
      enabled: false
    },
    status: '',
    statusMessage: '',
    subnetwork: '',
    tpuConfig: {
      enabled: false,
      ipv4CidrBlock: '',
      useServiceNetworking: false
    },
    tpuIpv4CidrBlock: '',
    verticalPodAutoscaling: {
      enabled: false
    },
    workloadAltsConfig: {
      enableAlts: false
    },
    workloadCertificates: {
      enableCertificates: false
    },
    workloadIdentityConfig: {
      identityNamespace: '',
      identityProvider: '',
      workloadPool: ''
    },
    zone: ''
  },
  parent: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/clusters',
  headers: {'content-type': 'application/json'},
  data: {
    cluster: {
      addonsConfig: {
        cloudRunConfig: {disabled: false, loadBalancerType: ''},
        configConnectorConfig: {enabled: false},
        dnsCacheConfig: {enabled: false},
        gcePersistentDiskCsiDriverConfig: {enabled: false},
        gcpFilestoreCsiDriverConfig: {enabled: false},
        gkeBackupAgentConfig: {enabled: false},
        horizontalPodAutoscaling: {disabled: false},
        httpLoadBalancing: {disabled: false},
        istioConfig: {auth: '', disabled: false},
        kalmConfig: {enabled: false},
        kubernetesDashboard: {disabled: false},
        networkPolicyConfig: {disabled: false}
      },
      authenticatorGroupsConfig: {enabled: false, securityGroup: ''},
      autopilot: {enabled: false},
      autoscaling: {
        autoprovisioningLocations: [],
        autoprovisioningNodePoolDefaults: {
          bootDiskKmsKey: '',
          diskSizeGb: 0,
          diskType: '',
          imageType: '',
          management: {
            autoRepair: false,
            autoUpgrade: false,
            upgradeOptions: {autoUpgradeStartTime: '', description: ''}
          },
          minCpuPlatform: '',
          oauthScopes: [],
          serviceAccount: '',
          shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
          upgradeSettings: {
            blueGreenSettings: {
              nodePoolSoakDuration: '',
              standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
            },
            maxSurge: 0,
            maxUnavailable: 0,
            strategy: ''
          }
        },
        autoscalingProfile: '',
        enableNodeAutoprovisioning: false,
        resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
      },
      binaryAuthorization: {enabled: false, evaluationMode: ''},
      clusterIpv4Cidr: '',
      clusterTelemetry: {type: ''},
      conditions: [{canonicalCode: '', code: '', message: ''}],
      confidentialNodes: {enabled: false},
      costManagementConfig: {enabled: false},
      createTime: '',
      currentMasterVersion: '',
      currentNodeCount: 0,
      currentNodeVersion: '',
      databaseEncryption: {keyName: '', state: ''},
      defaultMaxPodsConstraint: {maxPodsPerNode: ''},
      description: '',
      enableKubernetesAlpha: false,
      enableTpu: false,
      endpoint: '',
      etag: '',
      expireTime: '',
      fleet: {membership: '', preRegistered: false, project: ''},
      id: '',
      identityServiceConfig: {enabled: false},
      initialClusterVersion: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      ipAllocationPolicy: {
        additionalPodRangesConfig: {podRangeNames: []},
        allowRouteOverlap: false,
        clusterIpv4Cidr: '',
        clusterIpv4CidrBlock: '',
        clusterSecondaryRangeName: '',
        createSubnetwork: false,
        ipv6AccessType: '',
        nodeIpv4Cidr: '',
        nodeIpv4CidrBlock: '',
        podCidrOverprovisionConfig: {disable: false},
        servicesIpv4Cidr: '',
        servicesIpv4CidrBlock: '',
        servicesIpv6CidrBlock: '',
        servicesSecondaryRangeName: '',
        stackType: '',
        subnetIpv6CidrBlock: '',
        subnetworkName: '',
        tpuIpv4CidrBlock: '',
        useIpAliases: false,
        useRoutes: false
      },
      labelFingerprint: '',
      legacyAbac: {enabled: false},
      location: '',
      locations: [],
      loggingConfig: {componentConfig: {enableComponents: []}},
      loggingService: '',
      maintenancePolicy: {
        resourceVersion: '',
        window: {
          dailyMaintenanceWindow: {duration: '', startTime: ''},
          maintenanceExclusions: {},
          recurringWindow: {
            recurrence: '',
            window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
          }
        }
      },
      master: {},
      masterAuth: {
        clientCertificate: '',
        clientCertificateConfig: {issueClientCertificate: false},
        clientKey: '',
        clusterCaCertificate: '',
        password: '',
        username: ''
      },
      masterAuthorizedNetworksConfig: {
        cidrBlocks: [{cidrBlock: '', displayName: ''}],
        enabled: false,
        gcpPublicCidrsAccessEnabled: false
      },
      masterIpv4CidrBlock: '',
      meshCertificates: {enableCertificates: false},
      monitoringConfig: {
        componentConfig: {enableComponents: []},
        managedPrometheusConfig: {enabled: false}
      },
      monitoringService: '',
      name: '',
      network: '',
      networkConfig: {
        datapathProvider: '',
        defaultSnatStatus: {disabled: false},
        dnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
        enableIntraNodeVisibility: false,
        enableL4ilbSubsetting: false,
        gatewayApiConfig: {channel: ''},
        network: '',
        privateIpv6GoogleAccess: '',
        serviceExternalIpsConfig: {enabled: false},
        subnetwork: ''
      },
      networkPolicy: {enabled: false, provider: ''},
      nodeConfig: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      nodeIpv4CidrSize: 0,
      nodePoolAutoConfig: {networkTags: {tags: []}},
      nodePoolDefaults: {nodeConfigDefaults: {gcfsConfig: {}, loggingConfig: {}}},
      nodePools: [
        {
          autoscaling: {
            autoprovisioned: false,
            enabled: false,
            locationPolicy: '',
            maxNodeCount: 0,
            minNodeCount: 0,
            totalMaxNodeCount: 0,
            totalMinNodeCount: 0
          },
          conditions: [{}],
          config: {},
          etag: '',
          initialNodeCount: 0,
          instanceGroupUrls: [],
          locations: [],
          management: {},
          maxPodsConstraint: {},
          name: '',
          networkConfig: {
            createPodRange: false,
            enablePrivateNodes: false,
            networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
            podCidrOverprovisionConfig: {},
            podIpv4CidrBlock: '',
            podRange: ''
          },
          placementPolicy: {type: ''},
          podIpv4CidrSize: 0,
          selfLink: '',
          status: '',
          statusMessage: '',
          updateInfo: {
            blueGreenInfo: {
              blueInstanceGroupUrls: [],
              bluePoolDeletionStartTime: '',
              greenInstanceGroupUrls: [],
              greenPoolVersion: '',
              phase: ''
            }
          },
          upgradeSettings: {},
          version: ''
        }
      ],
      notificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
      podSecurityPolicyConfig: {enabled: false},
      privateCluster: false,
      privateClusterConfig: {
        enablePrivateEndpoint: false,
        enablePrivateNodes: false,
        masterGlobalAccessConfig: {enabled: false},
        masterIpv4CidrBlock: '',
        peeringName: '',
        privateEndpoint: '',
        privateEndpointSubnetwork: '',
        publicEndpoint: ''
      },
      protectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
      releaseChannel: {channel: ''},
      resourceLabels: {},
      resourceUsageExportConfig: {
        bigqueryDestination: {datasetId: ''},
        consumptionMeteringConfig: {enabled: false},
        enableNetworkEgressMetering: false
      },
      selfLink: '',
      servicesIpv4Cidr: '',
      shieldedNodes: {enabled: false},
      status: '',
      statusMessage: '',
      subnetwork: '',
      tpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
      tpuIpv4CidrBlock: '',
      verticalPodAutoscaling: {enabled: false},
      workloadAltsConfig: {enableAlts: false},
      workloadCertificates: {enableCertificates: false},
      workloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
      zone: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent/clusters';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cluster":{"addonsConfig":{"cloudRunConfig":{"disabled":false,"loadBalancerType":""},"configConnectorConfig":{"enabled":false},"dnsCacheConfig":{"enabled":false},"gcePersistentDiskCsiDriverConfig":{"enabled":false},"gcpFilestoreCsiDriverConfig":{"enabled":false},"gkeBackupAgentConfig":{"enabled":false},"horizontalPodAutoscaling":{"disabled":false},"httpLoadBalancing":{"disabled":false},"istioConfig":{"auth":"","disabled":false},"kalmConfig":{"enabled":false},"kubernetesDashboard":{"disabled":false},"networkPolicyConfig":{"disabled":false}},"authenticatorGroupsConfig":{"enabled":false,"securityGroup":""},"autopilot":{"enabled":false},"autoscaling":{"autoprovisioningLocations":[],"autoprovisioningNodePoolDefaults":{"bootDiskKmsKey":"","diskSizeGb":0,"diskType":"","imageType":"","management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"minCpuPlatform":"","oauthScopes":[],"serviceAccount":"","shieldedInstanceConfig":{"enableIntegrityMonitoring":false,"enableSecureBoot":false},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""}},"autoscalingProfile":"","enableNodeAutoprovisioning":false,"resourceLimits":[{"maximum":"","minimum":"","resourceType":""}]},"binaryAuthorization":{"enabled":false,"evaluationMode":""},"clusterIpv4Cidr":"","clusterTelemetry":{"type":""},"conditions":[{"canonicalCode":"","code":"","message":""}],"confidentialNodes":{"enabled":false},"costManagementConfig":{"enabled":false},"createTime":"","currentMasterVersion":"","currentNodeCount":0,"currentNodeVersion":"","databaseEncryption":{"keyName":"","state":""},"defaultMaxPodsConstraint":{"maxPodsPerNode":""},"description":"","enableKubernetesAlpha":false,"enableTpu":false,"endpoint":"","etag":"","expireTime":"","fleet":{"membership":"","preRegistered":false,"project":""},"id":"","identityServiceConfig":{"enabled":false},"initialClusterVersion":"","initialNodeCount":0,"instanceGroupUrls":[],"ipAllocationPolicy":{"additionalPodRangesConfig":{"podRangeNames":[]},"allowRouteOverlap":false,"clusterIpv4Cidr":"","clusterIpv4CidrBlock":"","clusterSecondaryRangeName":"","createSubnetwork":false,"ipv6AccessType":"","nodeIpv4Cidr":"","nodeIpv4CidrBlock":"","podCidrOverprovisionConfig":{"disable":false},"servicesIpv4Cidr":"","servicesIpv4CidrBlock":"","servicesIpv6CidrBlock":"","servicesSecondaryRangeName":"","stackType":"","subnetIpv6CidrBlock":"","subnetworkName":"","tpuIpv4CidrBlock":"","useIpAliases":false,"useRoutes":false},"labelFingerprint":"","legacyAbac":{"enabled":false},"location":"","locations":[],"loggingConfig":{"componentConfig":{"enableComponents":[]}},"loggingService":"","maintenancePolicy":{"resourceVersion":"","window":{"dailyMaintenanceWindow":{"duration":"","startTime":""},"maintenanceExclusions":{},"recurringWindow":{"recurrence":"","window":{"endTime":"","maintenanceExclusionOptions":{"scope":""},"startTime":""}}}},"master":{},"masterAuth":{"clientCertificate":"","clientCertificateConfig":{"issueClientCertificate":false},"clientKey":"","clusterCaCertificate":"","password":"","username":""},"masterAuthorizedNetworksConfig":{"cidrBlocks":[{"cidrBlock":"","displayName":""}],"enabled":false,"gcpPublicCidrsAccessEnabled":false},"masterIpv4CidrBlock":"","meshCertificates":{"enableCertificates":false},"monitoringConfig":{"componentConfig":{"enableComponents":[]},"managedPrometheusConfig":{"enabled":false}},"monitoringService":"","name":"","network":"","networkConfig":{"datapathProvider":"","defaultSnatStatus":{"disabled":false},"dnsConfig":{"clusterDns":"","clusterDnsDomain":"","clusterDnsScope":""},"enableIntraNodeVisibility":false,"enableL4ilbSubsetting":false,"gatewayApiConfig":{"channel":""},"network":"","privateIpv6GoogleAccess":"","serviceExternalIpsConfig":{"enabled":false},"subnetwork":""},"networkPolicy":{"enabled":false,"provider":""},"nodeConfig":{"accelerators":[{"acceleratorCount":"","acceleratorType":"","gpuPartitionSize":"","gpuSharingConfig":{"gpuSharingStrategy":"","maxSharedClientsPerGpu":""},"maxTimeSharedClientsPerGpu":""}],"advancedMachineFeatures":{"threadsPerCore":""},"bootDiskKmsKey":"","confidentialNodes":{},"diskSizeGb":0,"diskType":"","ephemeralStorageConfig":{"localSsdCount":0},"ephemeralStorageLocalSsdConfig":{"localSsdCount":0},"fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"localNvmeSsdBlockConfig":{"localSsdCount":0},"localSsdCount":0,"loggingConfig":{"variantConfig":{"variant":""}},"machineType":"","metadata":{},"minCpuPlatform":"","nodeGroup":"","oauthScopes":[],"preemptible":false,"reservationAffinity":{"consumeReservationType":"","key":"","values":[]},"resourceLabels":{},"sandboxConfig":{"sandboxType":"","type":""},"serviceAccount":"","shieldedInstanceConfig":{},"spot":false,"tags":[],"taints":[{"effect":"","key":"","value":""}],"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""}},"nodeIpv4CidrSize":0,"nodePoolAutoConfig":{"networkTags":{"tags":[]}},"nodePoolDefaults":{"nodeConfigDefaults":{"gcfsConfig":{},"loggingConfig":{}}},"nodePools":[{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"conditions":[{}],"config":{},"etag":"","initialNodeCount":0,"instanceGroupUrls":[],"locations":[],"management":{},"maxPodsConstraint":{},"name":"","networkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{},"podIpv4CidrBlock":"","podRange":""},"placementPolicy":{"type":""},"podIpv4CidrSize":0,"selfLink":"","status":"","statusMessage":"","updateInfo":{"blueGreenInfo":{"blueInstanceGroupUrls":[],"bluePoolDeletionStartTime":"","greenInstanceGroupUrls":[],"greenPoolVersion":"","phase":""}},"upgradeSettings":{},"version":""}],"notificationConfig":{"pubsub":{"enabled":false,"filter":{"eventType":[]},"topic":""}},"podSecurityPolicyConfig":{"enabled":false},"privateCluster":false,"privateClusterConfig":{"enablePrivateEndpoint":false,"enablePrivateNodes":false,"masterGlobalAccessConfig":{"enabled":false},"masterIpv4CidrBlock":"","peeringName":"","privateEndpoint":"","privateEndpointSubnetwork":"","publicEndpoint":""},"protectConfig":{"workloadConfig":{"auditMode":""},"workloadVulnerabilityMode":""},"releaseChannel":{"channel":""},"resourceLabels":{},"resourceUsageExportConfig":{"bigqueryDestination":{"datasetId":""},"consumptionMeteringConfig":{"enabled":false},"enableNetworkEgressMetering":false},"selfLink":"","servicesIpv4Cidr":"","shieldedNodes":{"enabled":false},"status":"","statusMessage":"","subnetwork":"","tpuConfig":{"enabled":false,"ipv4CidrBlock":"","useServiceNetworking":false},"tpuIpv4CidrBlock":"","verticalPodAutoscaling":{"enabled":false},"workloadAltsConfig":{"enableAlts":false},"workloadCertificates":{"enableCertificates":false},"workloadIdentityConfig":{"identityNamespace":"","identityProvider":"","workloadPool":""},"zone":""},"parent":"","projectId":"","zone":""}'
};

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}}/v1beta1/:parent/clusters',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cluster": {\n    "addonsConfig": {\n      "cloudRunConfig": {\n        "disabled": false,\n        "loadBalancerType": ""\n      },\n      "configConnectorConfig": {\n        "enabled": false\n      },\n      "dnsCacheConfig": {\n        "enabled": false\n      },\n      "gcePersistentDiskCsiDriverConfig": {\n        "enabled": false\n      },\n      "gcpFilestoreCsiDriverConfig": {\n        "enabled": false\n      },\n      "gkeBackupAgentConfig": {\n        "enabled": false\n      },\n      "horizontalPodAutoscaling": {\n        "disabled": false\n      },\n      "httpLoadBalancing": {\n        "disabled": false\n      },\n      "istioConfig": {\n        "auth": "",\n        "disabled": false\n      },\n      "kalmConfig": {\n        "enabled": false\n      },\n      "kubernetesDashboard": {\n        "disabled": false\n      },\n      "networkPolicyConfig": {\n        "disabled": false\n      }\n    },\n    "authenticatorGroupsConfig": {\n      "enabled": false,\n      "securityGroup": ""\n    },\n    "autopilot": {\n      "enabled": false\n    },\n    "autoscaling": {\n      "autoprovisioningLocations": [],\n      "autoprovisioningNodePoolDefaults": {\n        "bootDiskKmsKey": "",\n        "diskSizeGb": 0,\n        "diskType": "",\n        "imageType": "",\n        "management": {\n          "autoRepair": false,\n          "autoUpgrade": false,\n          "upgradeOptions": {\n            "autoUpgradeStartTime": "",\n            "description": ""\n          }\n        },\n        "minCpuPlatform": "",\n        "oauthScopes": [],\n        "serviceAccount": "",\n        "shieldedInstanceConfig": {\n          "enableIntegrityMonitoring": false,\n          "enableSecureBoot": false\n        },\n        "upgradeSettings": {\n          "blueGreenSettings": {\n            "nodePoolSoakDuration": "",\n            "standardRolloutPolicy": {\n              "batchNodeCount": 0,\n              "batchPercentage": "",\n              "batchSoakDuration": ""\n            }\n          },\n          "maxSurge": 0,\n          "maxUnavailable": 0,\n          "strategy": ""\n        }\n      },\n      "autoscalingProfile": "",\n      "enableNodeAutoprovisioning": false,\n      "resourceLimits": [\n        {\n          "maximum": "",\n          "minimum": "",\n          "resourceType": ""\n        }\n      ]\n    },\n    "binaryAuthorization": {\n      "enabled": false,\n      "evaluationMode": ""\n    },\n    "clusterIpv4Cidr": "",\n    "clusterTelemetry": {\n      "type": ""\n    },\n    "conditions": [\n      {\n        "canonicalCode": "",\n        "code": "",\n        "message": ""\n      }\n    ],\n    "confidentialNodes": {\n      "enabled": false\n    },\n    "costManagementConfig": {\n      "enabled": false\n    },\n    "createTime": "",\n    "currentMasterVersion": "",\n    "currentNodeCount": 0,\n    "currentNodeVersion": "",\n    "databaseEncryption": {\n      "keyName": "",\n      "state": ""\n    },\n    "defaultMaxPodsConstraint": {\n      "maxPodsPerNode": ""\n    },\n    "description": "",\n    "enableKubernetesAlpha": false,\n    "enableTpu": false,\n    "endpoint": "",\n    "etag": "",\n    "expireTime": "",\n    "fleet": {\n      "membership": "",\n      "preRegistered": false,\n      "project": ""\n    },\n    "id": "",\n    "identityServiceConfig": {\n      "enabled": false\n    },\n    "initialClusterVersion": "",\n    "initialNodeCount": 0,\n    "instanceGroupUrls": [],\n    "ipAllocationPolicy": {\n      "additionalPodRangesConfig": {\n        "podRangeNames": []\n      },\n      "allowRouteOverlap": false,\n      "clusterIpv4Cidr": "",\n      "clusterIpv4CidrBlock": "",\n      "clusterSecondaryRangeName": "",\n      "createSubnetwork": false,\n      "ipv6AccessType": "",\n      "nodeIpv4Cidr": "",\n      "nodeIpv4CidrBlock": "",\n      "podCidrOverprovisionConfig": {\n        "disable": false\n      },\n      "servicesIpv4Cidr": "",\n      "servicesIpv4CidrBlock": "",\n      "servicesIpv6CidrBlock": "",\n      "servicesSecondaryRangeName": "",\n      "stackType": "",\n      "subnetIpv6CidrBlock": "",\n      "subnetworkName": "",\n      "tpuIpv4CidrBlock": "",\n      "useIpAliases": false,\n      "useRoutes": false\n    },\n    "labelFingerprint": "",\n    "legacyAbac": {\n      "enabled": false\n    },\n    "location": "",\n    "locations": [],\n    "loggingConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      }\n    },\n    "loggingService": "",\n    "maintenancePolicy": {\n      "resourceVersion": "",\n      "window": {\n        "dailyMaintenanceWindow": {\n          "duration": "",\n          "startTime": ""\n        },\n        "maintenanceExclusions": {},\n        "recurringWindow": {\n          "recurrence": "",\n          "window": {\n            "endTime": "",\n            "maintenanceExclusionOptions": {\n              "scope": ""\n            },\n            "startTime": ""\n          }\n        }\n      }\n    },\n    "master": {},\n    "masterAuth": {\n      "clientCertificate": "",\n      "clientCertificateConfig": {\n        "issueClientCertificate": false\n      },\n      "clientKey": "",\n      "clusterCaCertificate": "",\n      "password": "",\n      "username": ""\n    },\n    "masterAuthorizedNetworksConfig": {\n      "cidrBlocks": [\n        {\n          "cidrBlock": "",\n          "displayName": ""\n        }\n      ],\n      "enabled": false,\n      "gcpPublicCidrsAccessEnabled": false\n    },\n    "masterIpv4CidrBlock": "",\n    "meshCertificates": {\n      "enableCertificates": false\n    },\n    "monitoringConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      },\n      "managedPrometheusConfig": {\n        "enabled": false\n      }\n    },\n    "monitoringService": "",\n    "name": "",\n    "network": "",\n    "networkConfig": {\n      "datapathProvider": "",\n      "defaultSnatStatus": {\n        "disabled": false\n      },\n      "dnsConfig": {\n        "clusterDns": "",\n        "clusterDnsDomain": "",\n        "clusterDnsScope": ""\n      },\n      "enableIntraNodeVisibility": false,\n      "enableL4ilbSubsetting": false,\n      "gatewayApiConfig": {\n        "channel": ""\n      },\n      "network": "",\n      "privateIpv6GoogleAccess": "",\n      "serviceExternalIpsConfig": {\n        "enabled": false\n      },\n      "subnetwork": ""\n    },\n    "networkPolicy": {\n      "enabled": false,\n      "provider": ""\n    },\n    "nodeConfig": {\n      "accelerators": [\n        {\n          "acceleratorCount": "",\n          "acceleratorType": "",\n          "gpuPartitionSize": "",\n          "gpuSharingConfig": {\n            "gpuSharingStrategy": "",\n            "maxSharedClientsPerGpu": ""\n          },\n          "maxTimeSharedClientsPerGpu": ""\n        }\n      ],\n      "advancedMachineFeatures": {\n        "threadsPerCore": ""\n      },\n      "bootDiskKmsKey": "",\n      "confidentialNodes": {},\n      "diskSizeGb": 0,\n      "diskType": "",\n      "ephemeralStorageConfig": {\n        "localSsdCount": 0\n      },\n      "ephemeralStorageLocalSsdConfig": {\n        "localSsdCount": 0\n      },\n      "fastSocket": {\n        "enabled": false\n      },\n      "gcfsConfig": {\n        "enabled": false\n      },\n      "gvnic": {\n        "enabled": false\n      },\n      "imageType": "",\n      "kubeletConfig": {\n        "cpuCfsQuota": false,\n        "cpuCfsQuotaPeriod": "",\n        "cpuManagerPolicy": "",\n        "podPidsLimit": ""\n      },\n      "labels": {},\n      "linuxNodeConfig": {\n        "cgroupMode": "",\n        "sysctls": {}\n      },\n      "localNvmeSsdBlockConfig": {\n        "localSsdCount": 0\n      },\n      "localSsdCount": 0,\n      "loggingConfig": {\n        "variantConfig": {\n          "variant": ""\n        }\n      },\n      "machineType": "",\n      "metadata": {},\n      "minCpuPlatform": "",\n      "nodeGroup": "",\n      "oauthScopes": [],\n      "preemptible": false,\n      "reservationAffinity": {\n        "consumeReservationType": "",\n        "key": "",\n        "values": []\n      },\n      "resourceLabels": {},\n      "sandboxConfig": {\n        "sandboxType": "",\n        "type": ""\n      },\n      "serviceAccount": "",\n      "shieldedInstanceConfig": {},\n      "spot": false,\n      "tags": [],\n      "taints": [\n        {\n          "effect": "",\n          "key": "",\n          "value": ""\n        }\n      ],\n      "windowsNodeConfig": {\n        "osVersion": ""\n      },\n      "workloadMetadataConfig": {\n        "mode": "",\n        "nodeMetadata": ""\n      }\n    },\n    "nodeIpv4CidrSize": 0,\n    "nodePoolAutoConfig": {\n      "networkTags": {\n        "tags": []\n      }\n    },\n    "nodePoolDefaults": {\n      "nodeConfigDefaults": {\n        "gcfsConfig": {},\n        "loggingConfig": {}\n      }\n    },\n    "nodePools": [\n      {\n        "autoscaling": {\n          "autoprovisioned": false,\n          "enabled": false,\n          "locationPolicy": "",\n          "maxNodeCount": 0,\n          "minNodeCount": 0,\n          "totalMaxNodeCount": 0,\n          "totalMinNodeCount": 0\n        },\n        "conditions": [\n          {}\n        ],\n        "config": {},\n        "etag": "",\n        "initialNodeCount": 0,\n        "instanceGroupUrls": [],\n        "locations": [],\n        "management": {},\n        "maxPodsConstraint": {},\n        "name": "",\n        "networkConfig": {\n          "createPodRange": false,\n          "enablePrivateNodes": false,\n          "networkPerformanceConfig": {\n            "externalIpEgressBandwidthTier": "",\n            "totalEgressBandwidthTier": ""\n          },\n          "podCidrOverprovisionConfig": {},\n          "podIpv4CidrBlock": "",\n          "podRange": ""\n        },\n        "placementPolicy": {\n          "type": ""\n        },\n        "podIpv4CidrSize": 0,\n        "selfLink": "",\n        "status": "",\n        "statusMessage": "",\n        "updateInfo": {\n          "blueGreenInfo": {\n            "blueInstanceGroupUrls": [],\n            "bluePoolDeletionStartTime": "",\n            "greenInstanceGroupUrls": [],\n            "greenPoolVersion": "",\n            "phase": ""\n          }\n        },\n        "upgradeSettings": {},\n        "version": ""\n      }\n    ],\n    "notificationConfig": {\n      "pubsub": {\n        "enabled": false,\n        "filter": {\n          "eventType": []\n        },\n        "topic": ""\n      }\n    },\n    "podSecurityPolicyConfig": {\n      "enabled": false\n    },\n    "privateCluster": false,\n    "privateClusterConfig": {\n      "enablePrivateEndpoint": false,\n      "enablePrivateNodes": false,\n      "masterGlobalAccessConfig": {\n        "enabled": false\n      },\n      "masterIpv4CidrBlock": "",\n      "peeringName": "",\n      "privateEndpoint": "",\n      "privateEndpointSubnetwork": "",\n      "publicEndpoint": ""\n    },\n    "protectConfig": {\n      "workloadConfig": {\n        "auditMode": ""\n      },\n      "workloadVulnerabilityMode": ""\n    },\n    "releaseChannel": {\n      "channel": ""\n    },\n    "resourceLabels": {},\n    "resourceUsageExportConfig": {\n      "bigqueryDestination": {\n        "datasetId": ""\n      },\n      "consumptionMeteringConfig": {\n        "enabled": false\n      },\n      "enableNetworkEgressMetering": false\n    },\n    "selfLink": "",\n    "servicesIpv4Cidr": "",\n    "shieldedNodes": {\n      "enabled": false\n    },\n    "status": "",\n    "statusMessage": "",\n    "subnetwork": "",\n    "tpuConfig": {\n      "enabled": false,\n      "ipv4CidrBlock": "",\n      "useServiceNetworking": false\n    },\n    "tpuIpv4CidrBlock": "",\n    "verticalPodAutoscaling": {\n      "enabled": false\n    },\n    "workloadAltsConfig": {\n      "enableAlts": false\n    },\n    "workloadCertificates": {\n      "enableCertificates": false\n    },\n    "workloadIdentityConfig": {\n      "identityNamespace": "",\n      "identityProvider": "",\n      "workloadPool": ""\n    },\n    "zone": ""\n  },\n  "parent": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/clusters")
  .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/v1beta1/:parent/clusters',
  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({
  cluster: {
    addonsConfig: {
      cloudRunConfig: {disabled: false, loadBalancerType: ''},
      configConnectorConfig: {enabled: false},
      dnsCacheConfig: {enabled: false},
      gcePersistentDiskCsiDriverConfig: {enabled: false},
      gcpFilestoreCsiDriverConfig: {enabled: false},
      gkeBackupAgentConfig: {enabled: false},
      horizontalPodAutoscaling: {disabled: false},
      httpLoadBalancing: {disabled: false},
      istioConfig: {auth: '', disabled: false},
      kalmConfig: {enabled: false},
      kubernetesDashboard: {disabled: false},
      networkPolicyConfig: {disabled: false}
    },
    authenticatorGroupsConfig: {enabled: false, securityGroup: ''},
    autopilot: {enabled: false},
    autoscaling: {
      autoprovisioningLocations: [],
      autoprovisioningNodePoolDefaults: {
        bootDiskKmsKey: '',
        diskSizeGb: 0,
        diskType: '',
        imageType: '',
        management: {
          autoRepair: false,
          autoUpgrade: false,
          upgradeOptions: {autoUpgradeStartTime: '', description: ''}
        },
        minCpuPlatform: '',
        oauthScopes: [],
        serviceAccount: '',
        shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
        upgradeSettings: {
          blueGreenSettings: {
            nodePoolSoakDuration: '',
            standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
          },
          maxSurge: 0,
          maxUnavailable: 0,
          strategy: ''
        }
      },
      autoscalingProfile: '',
      enableNodeAutoprovisioning: false,
      resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
    },
    binaryAuthorization: {enabled: false, evaluationMode: ''},
    clusterIpv4Cidr: '',
    clusterTelemetry: {type: ''},
    conditions: [{canonicalCode: '', code: '', message: ''}],
    confidentialNodes: {enabled: false},
    costManagementConfig: {enabled: false},
    createTime: '',
    currentMasterVersion: '',
    currentNodeCount: 0,
    currentNodeVersion: '',
    databaseEncryption: {keyName: '', state: ''},
    defaultMaxPodsConstraint: {maxPodsPerNode: ''},
    description: '',
    enableKubernetesAlpha: false,
    enableTpu: false,
    endpoint: '',
    etag: '',
    expireTime: '',
    fleet: {membership: '', preRegistered: false, project: ''},
    id: '',
    identityServiceConfig: {enabled: false},
    initialClusterVersion: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    ipAllocationPolicy: {
      additionalPodRangesConfig: {podRangeNames: []},
      allowRouteOverlap: false,
      clusterIpv4Cidr: '',
      clusterIpv4CidrBlock: '',
      clusterSecondaryRangeName: '',
      createSubnetwork: false,
      ipv6AccessType: '',
      nodeIpv4Cidr: '',
      nodeIpv4CidrBlock: '',
      podCidrOverprovisionConfig: {disable: false},
      servicesIpv4Cidr: '',
      servicesIpv4CidrBlock: '',
      servicesIpv6CidrBlock: '',
      servicesSecondaryRangeName: '',
      stackType: '',
      subnetIpv6CidrBlock: '',
      subnetworkName: '',
      tpuIpv4CidrBlock: '',
      useIpAliases: false,
      useRoutes: false
    },
    labelFingerprint: '',
    legacyAbac: {enabled: false},
    location: '',
    locations: [],
    loggingConfig: {componentConfig: {enableComponents: []}},
    loggingService: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {duration: '', startTime: ''},
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
        }
      }
    },
    master: {},
    masterAuth: {
      clientCertificate: '',
      clientCertificateConfig: {issueClientCertificate: false},
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    masterAuthorizedNetworksConfig: {
      cidrBlocks: [{cidrBlock: '', displayName: ''}],
      enabled: false,
      gcpPublicCidrsAccessEnabled: false
    },
    masterIpv4CidrBlock: '',
    meshCertificates: {enableCertificates: false},
    monitoringConfig: {
      componentConfig: {enableComponents: []},
      managedPrometheusConfig: {enabled: false}
    },
    monitoringService: '',
    name: '',
    network: '',
    networkConfig: {
      datapathProvider: '',
      defaultSnatStatus: {disabled: false},
      dnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
      enableIntraNodeVisibility: false,
      enableL4ilbSubsetting: false,
      gatewayApiConfig: {channel: ''},
      network: '',
      privateIpv6GoogleAccess: '',
      serviceExternalIpsConfig: {enabled: false},
      subnetwork: ''
    },
    networkPolicy: {enabled: false, provider: ''},
    nodeConfig: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {threadsPerCore: ''},
      bootDiskKmsKey: '',
      confidentialNodes: {},
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {localSsdCount: 0},
      ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
      fastSocket: {enabled: false},
      gcfsConfig: {enabled: false},
      gvnic: {enabled: false},
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {cgroupMode: '', sysctls: {}},
      localNvmeSsdBlockConfig: {localSsdCount: 0},
      localSsdCount: 0,
      loggingConfig: {variantConfig: {variant: ''}},
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {consumeReservationType: '', key: '', values: []},
      resourceLabels: {},
      sandboxConfig: {sandboxType: '', type: ''},
      serviceAccount: '',
      shieldedInstanceConfig: {},
      spot: false,
      tags: [],
      taints: [{effect: '', key: '', value: ''}],
      windowsNodeConfig: {osVersion: ''},
      workloadMetadataConfig: {mode: '', nodeMetadata: ''}
    },
    nodeIpv4CidrSize: 0,
    nodePoolAutoConfig: {networkTags: {tags: []}},
    nodePoolDefaults: {nodeConfigDefaults: {gcfsConfig: {}, loggingConfig: {}}},
    nodePools: [
      {
        autoscaling: {
          autoprovisioned: false,
          enabled: false,
          locationPolicy: '',
          maxNodeCount: 0,
          minNodeCount: 0,
          totalMaxNodeCount: 0,
          totalMinNodeCount: 0
        },
        conditions: [{}],
        config: {},
        etag: '',
        initialNodeCount: 0,
        instanceGroupUrls: [],
        locations: [],
        management: {},
        maxPodsConstraint: {},
        name: '',
        networkConfig: {
          createPodRange: false,
          enablePrivateNodes: false,
          networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
          podCidrOverprovisionConfig: {},
          podIpv4CidrBlock: '',
          podRange: ''
        },
        placementPolicy: {type: ''},
        podIpv4CidrSize: 0,
        selfLink: '',
        status: '',
        statusMessage: '',
        updateInfo: {
          blueGreenInfo: {
            blueInstanceGroupUrls: [],
            bluePoolDeletionStartTime: '',
            greenInstanceGroupUrls: [],
            greenPoolVersion: '',
            phase: ''
          }
        },
        upgradeSettings: {},
        version: ''
      }
    ],
    notificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
    podSecurityPolicyConfig: {enabled: false},
    privateCluster: false,
    privateClusterConfig: {
      enablePrivateEndpoint: false,
      enablePrivateNodes: false,
      masterGlobalAccessConfig: {enabled: false},
      masterIpv4CidrBlock: '',
      peeringName: '',
      privateEndpoint: '',
      privateEndpointSubnetwork: '',
      publicEndpoint: ''
    },
    protectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
    releaseChannel: {channel: ''},
    resourceLabels: {},
    resourceUsageExportConfig: {
      bigqueryDestination: {datasetId: ''},
      consumptionMeteringConfig: {enabled: false},
      enableNetworkEgressMetering: false
    },
    selfLink: '',
    servicesIpv4Cidr: '',
    shieldedNodes: {enabled: false},
    status: '',
    statusMessage: '',
    subnetwork: '',
    tpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
    tpuIpv4CidrBlock: '',
    verticalPodAutoscaling: {enabled: false},
    workloadAltsConfig: {enableAlts: false},
    workloadCertificates: {enableCertificates: false},
    workloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
    zone: ''
  },
  parent: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/clusters',
  headers: {'content-type': 'application/json'},
  body: {
    cluster: {
      addonsConfig: {
        cloudRunConfig: {disabled: false, loadBalancerType: ''},
        configConnectorConfig: {enabled: false},
        dnsCacheConfig: {enabled: false},
        gcePersistentDiskCsiDriverConfig: {enabled: false},
        gcpFilestoreCsiDriverConfig: {enabled: false},
        gkeBackupAgentConfig: {enabled: false},
        horizontalPodAutoscaling: {disabled: false},
        httpLoadBalancing: {disabled: false},
        istioConfig: {auth: '', disabled: false},
        kalmConfig: {enabled: false},
        kubernetesDashboard: {disabled: false},
        networkPolicyConfig: {disabled: false}
      },
      authenticatorGroupsConfig: {enabled: false, securityGroup: ''},
      autopilot: {enabled: false},
      autoscaling: {
        autoprovisioningLocations: [],
        autoprovisioningNodePoolDefaults: {
          bootDiskKmsKey: '',
          diskSizeGb: 0,
          diskType: '',
          imageType: '',
          management: {
            autoRepair: false,
            autoUpgrade: false,
            upgradeOptions: {autoUpgradeStartTime: '', description: ''}
          },
          minCpuPlatform: '',
          oauthScopes: [],
          serviceAccount: '',
          shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
          upgradeSettings: {
            blueGreenSettings: {
              nodePoolSoakDuration: '',
              standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
            },
            maxSurge: 0,
            maxUnavailable: 0,
            strategy: ''
          }
        },
        autoscalingProfile: '',
        enableNodeAutoprovisioning: false,
        resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
      },
      binaryAuthorization: {enabled: false, evaluationMode: ''},
      clusterIpv4Cidr: '',
      clusterTelemetry: {type: ''},
      conditions: [{canonicalCode: '', code: '', message: ''}],
      confidentialNodes: {enabled: false},
      costManagementConfig: {enabled: false},
      createTime: '',
      currentMasterVersion: '',
      currentNodeCount: 0,
      currentNodeVersion: '',
      databaseEncryption: {keyName: '', state: ''},
      defaultMaxPodsConstraint: {maxPodsPerNode: ''},
      description: '',
      enableKubernetesAlpha: false,
      enableTpu: false,
      endpoint: '',
      etag: '',
      expireTime: '',
      fleet: {membership: '', preRegistered: false, project: ''},
      id: '',
      identityServiceConfig: {enabled: false},
      initialClusterVersion: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      ipAllocationPolicy: {
        additionalPodRangesConfig: {podRangeNames: []},
        allowRouteOverlap: false,
        clusterIpv4Cidr: '',
        clusterIpv4CidrBlock: '',
        clusterSecondaryRangeName: '',
        createSubnetwork: false,
        ipv6AccessType: '',
        nodeIpv4Cidr: '',
        nodeIpv4CidrBlock: '',
        podCidrOverprovisionConfig: {disable: false},
        servicesIpv4Cidr: '',
        servicesIpv4CidrBlock: '',
        servicesIpv6CidrBlock: '',
        servicesSecondaryRangeName: '',
        stackType: '',
        subnetIpv6CidrBlock: '',
        subnetworkName: '',
        tpuIpv4CidrBlock: '',
        useIpAliases: false,
        useRoutes: false
      },
      labelFingerprint: '',
      legacyAbac: {enabled: false},
      location: '',
      locations: [],
      loggingConfig: {componentConfig: {enableComponents: []}},
      loggingService: '',
      maintenancePolicy: {
        resourceVersion: '',
        window: {
          dailyMaintenanceWindow: {duration: '', startTime: ''},
          maintenanceExclusions: {},
          recurringWindow: {
            recurrence: '',
            window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
          }
        }
      },
      master: {},
      masterAuth: {
        clientCertificate: '',
        clientCertificateConfig: {issueClientCertificate: false},
        clientKey: '',
        clusterCaCertificate: '',
        password: '',
        username: ''
      },
      masterAuthorizedNetworksConfig: {
        cidrBlocks: [{cidrBlock: '', displayName: ''}],
        enabled: false,
        gcpPublicCidrsAccessEnabled: false
      },
      masterIpv4CidrBlock: '',
      meshCertificates: {enableCertificates: false},
      monitoringConfig: {
        componentConfig: {enableComponents: []},
        managedPrometheusConfig: {enabled: false}
      },
      monitoringService: '',
      name: '',
      network: '',
      networkConfig: {
        datapathProvider: '',
        defaultSnatStatus: {disabled: false},
        dnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
        enableIntraNodeVisibility: false,
        enableL4ilbSubsetting: false,
        gatewayApiConfig: {channel: ''},
        network: '',
        privateIpv6GoogleAccess: '',
        serviceExternalIpsConfig: {enabled: false},
        subnetwork: ''
      },
      networkPolicy: {enabled: false, provider: ''},
      nodeConfig: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      nodeIpv4CidrSize: 0,
      nodePoolAutoConfig: {networkTags: {tags: []}},
      nodePoolDefaults: {nodeConfigDefaults: {gcfsConfig: {}, loggingConfig: {}}},
      nodePools: [
        {
          autoscaling: {
            autoprovisioned: false,
            enabled: false,
            locationPolicy: '',
            maxNodeCount: 0,
            minNodeCount: 0,
            totalMaxNodeCount: 0,
            totalMinNodeCount: 0
          },
          conditions: [{}],
          config: {},
          etag: '',
          initialNodeCount: 0,
          instanceGroupUrls: [],
          locations: [],
          management: {},
          maxPodsConstraint: {},
          name: '',
          networkConfig: {
            createPodRange: false,
            enablePrivateNodes: false,
            networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
            podCidrOverprovisionConfig: {},
            podIpv4CidrBlock: '',
            podRange: ''
          },
          placementPolicy: {type: ''},
          podIpv4CidrSize: 0,
          selfLink: '',
          status: '',
          statusMessage: '',
          updateInfo: {
            blueGreenInfo: {
              blueInstanceGroupUrls: [],
              bluePoolDeletionStartTime: '',
              greenInstanceGroupUrls: [],
              greenPoolVersion: '',
              phase: ''
            }
          },
          upgradeSettings: {},
          version: ''
        }
      ],
      notificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
      podSecurityPolicyConfig: {enabled: false},
      privateCluster: false,
      privateClusterConfig: {
        enablePrivateEndpoint: false,
        enablePrivateNodes: false,
        masterGlobalAccessConfig: {enabled: false},
        masterIpv4CidrBlock: '',
        peeringName: '',
        privateEndpoint: '',
        privateEndpointSubnetwork: '',
        publicEndpoint: ''
      },
      protectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
      releaseChannel: {channel: ''},
      resourceLabels: {},
      resourceUsageExportConfig: {
        bigqueryDestination: {datasetId: ''},
        consumptionMeteringConfig: {enabled: false},
        enableNetworkEgressMetering: false
      },
      selfLink: '',
      servicesIpv4Cidr: '',
      shieldedNodes: {enabled: false},
      status: '',
      statusMessage: '',
      subnetwork: '',
      tpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
      tpuIpv4CidrBlock: '',
      verticalPodAutoscaling: {enabled: false},
      workloadAltsConfig: {enableAlts: false},
      workloadCertificates: {enableCertificates: false},
      workloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
      zone: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/:parent/clusters');

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

req.type('json');
req.send({
  cluster: {
    addonsConfig: {
      cloudRunConfig: {
        disabled: false,
        loadBalancerType: ''
      },
      configConnectorConfig: {
        enabled: false
      },
      dnsCacheConfig: {
        enabled: false
      },
      gcePersistentDiskCsiDriverConfig: {
        enabled: false
      },
      gcpFilestoreCsiDriverConfig: {
        enabled: false
      },
      gkeBackupAgentConfig: {
        enabled: false
      },
      horizontalPodAutoscaling: {
        disabled: false
      },
      httpLoadBalancing: {
        disabled: false
      },
      istioConfig: {
        auth: '',
        disabled: false
      },
      kalmConfig: {
        enabled: false
      },
      kubernetesDashboard: {
        disabled: false
      },
      networkPolicyConfig: {
        disabled: false
      }
    },
    authenticatorGroupsConfig: {
      enabled: false,
      securityGroup: ''
    },
    autopilot: {
      enabled: false
    },
    autoscaling: {
      autoprovisioningLocations: [],
      autoprovisioningNodePoolDefaults: {
        bootDiskKmsKey: '',
        diskSizeGb: 0,
        diskType: '',
        imageType: '',
        management: {
          autoRepair: false,
          autoUpgrade: false,
          upgradeOptions: {
            autoUpgradeStartTime: '',
            description: ''
          }
        },
        minCpuPlatform: '',
        oauthScopes: [],
        serviceAccount: '',
        shieldedInstanceConfig: {
          enableIntegrityMonitoring: false,
          enableSecureBoot: false
        },
        upgradeSettings: {
          blueGreenSettings: {
            nodePoolSoakDuration: '',
            standardRolloutPolicy: {
              batchNodeCount: 0,
              batchPercentage: '',
              batchSoakDuration: ''
            }
          },
          maxSurge: 0,
          maxUnavailable: 0,
          strategy: ''
        }
      },
      autoscalingProfile: '',
      enableNodeAutoprovisioning: false,
      resourceLimits: [
        {
          maximum: '',
          minimum: '',
          resourceType: ''
        }
      ]
    },
    binaryAuthorization: {
      enabled: false,
      evaluationMode: ''
    },
    clusterIpv4Cidr: '',
    clusterTelemetry: {
      type: ''
    },
    conditions: [
      {
        canonicalCode: '',
        code: '',
        message: ''
      }
    ],
    confidentialNodes: {
      enabled: false
    },
    costManagementConfig: {
      enabled: false
    },
    createTime: '',
    currentMasterVersion: '',
    currentNodeCount: 0,
    currentNodeVersion: '',
    databaseEncryption: {
      keyName: '',
      state: ''
    },
    defaultMaxPodsConstraint: {
      maxPodsPerNode: ''
    },
    description: '',
    enableKubernetesAlpha: false,
    enableTpu: false,
    endpoint: '',
    etag: '',
    expireTime: '',
    fleet: {
      membership: '',
      preRegistered: false,
      project: ''
    },
    id: '',
    identityServiceConfig: {
      enabled: false
    },
    initialClusterVersion: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    ipAllocationPolicy: {
      additionalPodRangesConfig: {
        podRangeNames: []
      },
      allowRouteOverlap: false,
      clusterIpv4Cidr: '',
      clusterIpv4CidrBlock: '',
      clusterSecondaryRangeName: '',
      createSubnetwork: false,
      ipv6AccessType: '',
      nodeIpv4Cidr: '',
      nodeIpv4CidrBlock: '',
      podCidrOverprovisionConfig: {
        disable: false
      },
      servicesIpv4Cidr: '',
      servicesIpv4CidrBlock: '',
      servicesIpv6CidrBlock: '',
      servicesSecondaryRangeName: '',
      stackType: '',
      subnetIpv6CidrBlock: '',
      subnetworkName: '',
      tpuIpv4CidrBlock: '',
      useIpAliases: false,
      useRoutes: false
    },
    labelFingerprint: '',
    legacyAbac: {
      enabled: false
    },
    location: '',
    locations: [],
    loggingConfig: {
      componentConfig: {
        enableComponents: []
      }
    },
    loggingService: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {
          duration: '',
          startTime: ''
        },
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {
            endTime: '',
            maintenanceExclusionOptions: {
              scope: ''
            },
            startTime: ''
          }
        }
      }
    },
    master: {},
    masterAuth: {
      clientCertificate: '',
      clientCertificateConfig: {
        issueClientCertificate: false
      },
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    masterAuthorizedNetworksConfig: {
      cidrBlocks: [
        {
          cidrBlock: '',
          displayName: ''
        }
      ],
      enabled: false,
      gcpPublicCidrsAccessEnabled: false
    },
    masterIpv4CidrBlock: '',
    meshCertificates: {
      enableCertificates: false
    },
    monitoringConfig: {
      componentConfig: {
        enableComponents: []
      },
      managedPrometheusConfig: {
        enabled: false
      }
    },
    monitoringService: '',
    name: '',
    network: '',
    networkConfig: {
      datapathProvider: '',
      defaultSnatStatus: {
        disabled: false
      },
      dnsConfig: {
        clusterDns: '',
        clusterDnsDomain: '',
        clusterDnsScope: ''
      },
      enableIntraNodeVisibility: false,
      enableL4ilbSubsetting: false,
      gatewayApiConfig: {
        channel: ''
      },
      network: '',
      privateIpv6GoogleAccess: '',
      serviceExternalIpsConfig: {
        enabled: false
      },
      subnetwork: ''
    },
    networkPolicy: {
      enabled: false,
      provider: ''
    },
    nodeConfig: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {
            gpuSharingStrategy: '',
            maxSharedClientsPerGpu: ''
          },
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {
        threadsPerCore: ''
      },
      bootDiskKmsKey: '',
      confidentialNodes: {},
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {
        localSsdCount: 0
      },
      ephemeralStorageLocalSsdConfig: {
        localSsdCount: 0
      },
      fastSocket: {
        enabled: false
      },
      gcfsConfig: {
        enabled: false
      },
      gvnic: {
        enabled: false
      },
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {
        cgroupMode: '',
        sysctls: {}
      },
      localNvmeSsdBlockConfig: {
        localSsdCount: 0
      },
      localSsdCount: 0,
      loggingConfig: {
        variantConfig: {
          variant: ''
        }
      },
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {
        consumeReservationType: '',
        key: '',
        values: []
      },
      resourceLabels: {},
      sandboxConfig: {
        sandboxType: '',
        type: ''
      },
      serviceAccount: '',
      shieldedInstanceConfig: {},
      spot: false,
      tags: [],
      taints: [
        {
          effect: '',
          key: '',
          value: ''
        }
      ],
      windowsNodeConfig: {
        osVersion: ''
      },
      workloadMetadataConfig: {
        mode: '',
        nodeMetadata: ''
      }
    },
    nodeIpv4CidrSize: 0,
    nodePoolAutoConfig: {
      networkTags: {
        tags: []
      }
    },
    nodePoolDefaults: {
      nodeConfigDefaults: {
        gcfsConfig: {},
        loggingConfig: {}
      }
    },
    nodePools: [
      {
        autoscaling: {
          autoprovisioned: false,
          enabled: false,
          locationPolicy: '',
          maxNodeCount: 0,
          minNodeCount: 0,
          totalMaxNodeCount: 0,
          totalMinNodeCount: 0
        },
        conditions: [
          {}
        ],
        config: {},
        etag: '',
        initialNodeCount: 0,
        instanceGroupUrls: [],
        locations: [],
        management: {},
        maxPodsConstraint: {},
        name: '',
        networkConfig: {
          createPodRange: false,
          enablePrivateNodes: false,
          networkPerformanceConfig: {
            externalIpEgressBandwidthTier: '',
            totalEgressBandwidthTier: ''
          },
          podCidrOverprovisionConfig: {},
          podIpv4CidrBlock: '',
          podRange: ''
        },
        placementPolicy: {
          type: ''
        },
        podIpv4CidrSize: 0,
        selfLink: '',
        status: '',
        statusMessage: '',
        updateInfo: {
          blueGreenInfo: {
            blueInstanceGroupUrls: [],
            bluePoolDeletionStartTime: '',
            greenInstanceGroupUrls: [],
            greenPoolVersion: '',
            phase: ''
          }
        },
        upgradeSettings: {},
        version: ''
      }
    ],
    notificationConfig: {
      pubsub: {
        enabled: false,
        filter: {
          eventType: []
        },
        topic: ''
      }
    },
    podSecurityPolicyConfig: {
      enabled: false
    },
    privateCluster: false,
    privateClusterConfig: {
      enablePrivateEndpoint: false,
      enablePrivateNodes: false,
      masterGlobalAccessConfig: {
        enabled: false
      },
      masterIpv4CidrBlock: '',
      peeringName: '',
      privateEndpoint: '',
      privateEndpointSubnetwork: '',
      publicEndpoint: ''
    },
    protectConfig: {
      workloadConfig: {
        auditMode: ''
      },
      workloadVulnerabilityMode: ''
    },
    releaseChannel: {
      channel: ''
    },
    resourceLabels: {},
    resourceUsageExportConfig: {
      bigqueryDestination: {
        datasetId: ''
      },
      consumptionMeteringConfig: {
        enabled: false
      },
      enableNetworkEgressMetering: false
    },
    selfLink: '',
    servicesIpv4Cidr: '',
    shieldedNodes: {
      enabled: false
    },
    status: '',
    statusMessage: '',
    subnetwork: '',
    tpuConfig: {
      enabled: false,
      ipv4CidrBlock: '',
      useServiceNetworking: false
    },
    tpuIpv4CidrBlock: '',
    verticalPodAutoscaling: {
      enabled: false
    },
    workloadAltsConfig: {
      enableAlts: false
    },
    workloadCertificates: {
      enableCertificates: false
    },
    workloadIdentityConfig: {
      identityNamespace: '',
      identityProvider: '',
      workloadPool: ''
    },
    zone: ''
  },
  parent: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:parent/clusters',
  headers: {'content-type': 'application/json'},
  data: {
    cluster: {
      addonsConfig: {
        cloudRunConfig: {disabled: false, loadBalancerType: ''},
        configConnectorConfig: {enabled: false},
        dnsCacheConfig: {enabled: false},
        gcePersistentDiskCsiDriverConfig: {enabled: false},
        gcpFilestoreCsiDriverConfig: {enabled: false},
        gkeBackupAgentConfig: {enabled: false},
        horizontalPodAutoscaling: {disabled: false},
        httpLoadBalancing: {disabled: false},
        istioConfig: {auth: '', disabled: false},
        kalmConfig: {enabled: false},
        kubernetesDashboard: {disabled: false},
        networkPolicyConfig: {disabled: false}
      },
      authenticatorGroupsConfig: {enabled: false, securityGroup: ''},
      autopilot: {enabled: false},
      autoscaling: {
        autoprovisioningLocations: [],
        autoprovisioningNodePoolDefaults: {
          bootDiskKmsKey: '',
          diskSizeGb: 0,
          diskType: '',
          imageType: '',
          management: {
            autoRepair: false,
            autoUpgrade: false,
            upgradeOptions: {autoUpgradeStartTime: '', description: ''}
          },
          minCpuPlatform: '',
          oauthScopes: [],
          serviceAccount: '',
          shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
          upgradeSettings: {
            blueGreenSettings: {
              nodePoolSoakDuration: '',
              standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
            },
            maxSurge: 0,
            maxUnavailable: 0,
            strategy: ''
          }
        },
        autoscalingProfile: '',
        enableNodeAutoprovisioning: false,
        resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
      },
      binaryAuthorization: {enabled: false, evaluationMode: ''},
      clusterIpv4Cidr: '',
      clusterTelemetry: {type: ''},
      conditions: [{canonicalCode: '', code: '', message: ''}],
      confidentialNodes: {enabled: false},
      costManagementConfig: {enabled: false},
      createTime: '',
      currentMasterVersion: '',
      currentNodeCount: 0,
      currentNodeVersion: '',
      databaseEncryption: {keyName: '', state: ''},
      defaultMaxPodsConstraint: {maxPodsPerNode: ''},
      description: '',
      enableKubernetesAlpha: false,
      enableTpu: false,
      endpoint: '',
      etag: '',
      expireTime: '',
      fleet: {membership: '', preRegistered: false, project: ''},
      id: '',
      identityServiceConfig: {enabled: false},
      initialClusterVersion: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      ipAllocationPolicy: {
        additionalPodRangesConfig: {podRangeNames: []},
        allowRouteOverlap: false,
        clusterIpv4Cidr: '',
        clusterIpv4CidrBlock: '',
        clusterSecondaryRangeName: '',
        createSubnetwork: false,
        ipv6AccessType: '',
        nodeIpv4Cidr: '',
        nodeIpv4CidrBlock: '',
        podCidrOverprovisionConfig: {disable: false},
        servicesIpv4Cidr: '',
        servicesIpv4CidrBlock: '',
        servicesIpv6CidrBlock: '',
        servicesSecondaryRangeName: '',
        stackType: '',
        subnetIpv6CidrBlock: '',
        subnetworkName: '',
        tpuIpv4CidrBlock: '',
        useIpAliases: false,
        useRoutes: false
      },
      labelFingerprint: '',
      legacyAbac: {enabled: false},
      location: '',
      locations: [],
      loggingConfig: {componentConfig: {enableComponents: []}},
      loggingService: '',
      maintenancePolicy: {
        resourceVersion: '',
        window: {
          dailyMaintenanceWindow: {duration: '', startTime: ''},
          maintenanceExclusions: {},
          recurringWindow: {
            recurrence: '',
            window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
          }
        }
      },
      master: {},
      masterAuth: {
        clientCertificate: '',
        clientCertificateConfig: {issueClientCertificate: false},
        clientKey: '',
        clusterCaCertificate: '',
        password: '',
        username: ''
      },
      masterAuthorizedNetworksConfig: {
        cidrBlocks: [{cidrBlock: '', displayName: ''}],
        enabled: false,
        gcpPublicCidrsAccessEnabled: false
      },
      masterIpv4CidrBlock: '',
      meshCertificates: {enableCertificates: false},
      monitoringConfig: {
        componentConfig: {enableComponents: []},
        managedPrometheusConfig: {enabled: false}
      },
      monitoringService: '',
      name: '',
      network: '',
      networkConfig: {
        datapathProvider: '',
        defaultSnatStatus: {disabled: false},
        dnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
        enableIntraNodeVisibility: false,
        enableL4ilbSubsetting: false,
        gatewayApiConfig: {channel: ''},
        network: '',
        privateIpv6GoogleAccess: '',
        serviceExternalIpsConfig: {enabled: false},
        subnetwork: ''
      },
      networkPolicy: {enabled: false, provider: ''},
      nodeConfig: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      nodeIpv4CidrSize: 0,
      nodePoolAutoConfig: {networkTags: {tags: []}},
      nodePoolDefaults: {nodeConfigDefaults: {gcfsConfig: {}, loggingConfig: {}}},
      nodePools: [
        {
          autoscaling: {
            autoprovisioned: false,
            enabled: false,
            locationPolicy: '',
            maxNodeCount: 0,
            minNodeCount: 0,
            totalMaxNodeCount: 0,
            totalMinNodeCount: 0
          },
          conditions: [{}],
          config: {},
          etag: '',
          initialNodeCount: 0,
          instanceGroupUrls: [],
          locations: [],
          management: {},
          maxPodsConstraint: {},
          name: '',
          networkConfig: {
            createPodRange: false,
            enablePrivateNodes: false,
            networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
            podCidrOverprovisionConfig: {},
            podIpv4CidrBlock: '',
            podRange: ''
          },
          placementPolicy: {type: ''},
          podIpv4CidrSize: 0,
          selfLink: '',
          status: '',
          statusMessage: '',
          updateInfo: {
            blueGreenInfo: {
              blueInstanceGroupUrls: [],
              bluePoolDeletionStartTime: '',
              greenInstanceGroupUrls: [],
              greenPoolVersion: '',
              phase: ''
            }
          },
          upgradeSettings: {},
          version: ''
        }
      ],
      notificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
      podSecurityPolicyConfig: {enabled: false},
      privateCluster: false,
      privateClusterConfig: {
        enablePrivateEndpoint: false,
        enablePrivateNodes: false,
        masterGlobalAccessConfig: {enabled: false},
        masterIpv4CidrBlock: '',
        peeringName: '',
        privateEndpoint: '',
        privateEndpointSubnetwork: '',
        publicEndpoint: ''
      },
      protectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
      releaseChannel: {channel: ''},
      resourceLabels: {},
      resourceUsageExportConfig: {
        bigqueryDestination: {datasetId: ''},
        consumptionMeteringConfig: {enabled: false},
        enableNetworkEgressMetering: false
      },
      selfLink: '',
      servicesIpv4Cidr: '',
      shieldedNodes: {enabled: false},
      status: '',
      statusMessage: '',
      subnetwork: '',
      tpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
      tpuIpv4CidrBlock: '',
      verticalPodAutoscaling: {enabled: false},
      workloadAltsConfig: {enableAlts: false},
      workloadCertificates: {enableCertificates: false},
      workloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
      zone: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:parent/clusters';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cluster":{"addonsConfig":{"cloudRunConfig":{"disabled":false,"loadBalancerType":""},"configConnectorConfig":{"enabled":false},"dnsCacheConfig":{"enabled":false},"gcePersistentDiskCsiDriverConfig":{"enabled":false},"gcpFilestoreCsiDriverConfig":{"enabled":false},"gkeBackupAgentConfig":{"enabled":false},"horizontalPodAutoscaling":{"disabled":false},"httpLoadBalancing":{"disabled":false},"istioConfig":{"auth":"","disabled":false},"kalmConfig":{"enabled":false},"kubernetesDashboard":{"disabled":false},"networkPolicyConfig":{"disabled":false}},"authenticatorGroupsConfig":{"enabled":false,"securityGroup":""},"autopilot":{"enabled":false},"autoscaling":{"autoprovisioningLocations":[],"autoprovisioningNodePoolDefaults":{"bootDiskKmsKey":"","diskSizeGb":0,"diskType":"","imageType":"","management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"minCpuPlatform":"","oauthScopes":[],"serviceAccount":"","shieldedInstanceConfig":{"enableIntegrityMonitoring":false,"enableSecureBoot":false},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""}},"autoscalingProfile":"","enableNodeAutoprovisioning":false,"resourceLimits":[{"maximum":"","minimum":"","resourceType":""}]},"binaryAuthorization":{"enabled":false,"evaluationMode":""},"clusterIpv4Cidr":"","clusterTelemetry":{"type":""},"conditions":[{"canonicalCode":"","code":"","message":""}],"confidentialNodes":{"enabled":false},"costManagementConfig":{"enabled":false},"createTime":"","currentMasterVersion":"","currentNodeCount":0,"currentNodeVersion":"","databaseEncryption":{"keyName":"","state":""},"defaultMaxPodsConstraint":{"maxPodsPerNode":""},"description":"","enableKubernetesAlpha":false,"enableTpu":false,"endpoint":"","etag":"","expireTime":"","fleet":{"membership":"","preRegistered":false,"project":""},"id":"","identityServiceConfig":{"enabled":false},"initialClusterVersion":"","initialNodeCount":0,"instanceGroupUrls":[],"ipAllocationPolicy":{"additionalPodRangesConfig":{"podRangeNames":[]},"allowRouteOverlap":false,"clusterIpv4Cidr":"","clusterIpv4CidrBlock":"","clusterSecondaryRangeName":"","createSubnetwork":false,"ipv6AccessType":"","nodeIpv4Cidr":"","nodeIpv4CidrBlock":"","podCidrOverprovisionConfig":{"disable":false},"servicesIpv4Cidr":"","servicesIpv4CidrBlock":"","servicesIpv6CidrBlock":"","servicesSecondaryRangeName":"","stackType":"","subnetIpv6CidrBlock":"","subnetworkName":"","tpuIpv4CidrBlock":"","useIpAliases":false,"useRoutes":false},"labelFingerprint":"","legacyAbac":{"enabled":false},"location":"","locations":[],"loggingConfig":{"componentConfig":{"enableComponents":[]}},"loggingService":"","maintenancePolicy":{"resourceVersion":"","window":{"dailyMaintenanceWindow":{"duration":"","startTime":""},"maintenanceExclusions":{},"recurringWindow":{"recurrence":"","window":{"endTime":"","maintenanceExclusionOptions":{"scope":""},"startTime":""}}}},"master":{},"masterAuth":{"clientCertificate":"","clientCertificateConfig":{"issueClientCertificate":false},"clientKey":"","clusterCaCertificate":"","password":"","username":""},"masterAuthorizedNetworksConfig":{"cidrBlocks":[{"cidrBlock":"","displayName":""}],"enabled":false,"gcpPublicCidrsAccessEnabled":false},"masterIpv4CidrBlock":"","meshCertificates":{"enableCertificates":false},"monitoringConfig":{"componentConfig":{"enableComponents":[]},"managedPrometheusConfig":{"enabled":false}},"monitoringService":"","name":"","network":"","networkConfig":{"datapathProvider":"","defaultSnatStatus":{"disabled":false},"dnsConfig":{"clusterDns":"","clusterDnsDomain":"","clusterDnsScope":""},"enableIntraNodeVisibility":false,"enableL4ilbSubsetting":false,"gatewayApiConfig":{"channel":""},"network":"","privateIpv6GoogleAccess":"","serviceExternalIpsConfig":{"enabled":false},"subnetwork":""},"networkPolicy":{"enabled":false,"provider":""},"nodeConfig":{"accelerators":[{"acceleratorCount":"","acceleratorType":"","gpuPartitionSize":"","gpuSharingConfig":{"gpuSharingStrategy":"","maxSharedClientsPerGpu":""},"maxTimeSharedClientsPerGpu":""}],"advancedMachineFeatures":{"threadsPerCore":""},"bootDiskKmsKey":"","confidentialNodes":{},"diskSizeGb":0,"diskType":"","ephemeralStorageConfig":{"localSsdCount":0},"ephemeralStorageLocalSsdConfig":{"localSsdCount":0},"fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"localNvmeSsdBlockConfig":{"localSsdCount":0},"localSsdCount":0,"loggingConfig":{"variantConfig":{"variant":""}},"machineType":"","metadata":{},"minCpuPlatform":"","nodeGroup":"","oauthScopes":[],"preemptible":false,"reservationAffinity":{"consumeReservationType":"","key":"","values":[]},"resourceLabels":{},"sandboxConfig":{"sandboxType":"","type":""},"serviceAccount":"","shieldedInstanceConfig":{},"spot":false,"tags":[],"taints":[{"effect":"","key":"","value":""}],"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""}},"nodeIpv4CidrSize":0,"nodePoolAutoConfig":{"networkTags":{"tags":[]}},"nodePoolDefaults":{"nodeConfigDefaults":{"gcfsConfig":{},"loggingConfig":{}}},"nodePools":[{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"conditions":[{}],"config":{},"etag":"","initialNodeCount":0,"instanceGroupUrls":[],"locations":[],"management":{},"maxPodsConstraint":{},"name":"","networkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{},"podIpv4CidrBlock":"","podRange":""},"placementPolicy":{"type":""},"podIpv4CidrSize":0,"selfLink":"","status":"","statusMessage":"","updateInfo":{"blueGreenInfo":{"blueInstanceGroupUrls":[],"bluePoolDeletionStartTime":"","greenInstanceGroupUrls":[],"greenPoolVersion":"","phase":""}},"upgradeSettings":{},"version":""}],"notificationConfig":{"pubsub":{"enabled":false,"filter":{"eventType":[]},"topic":""}},"podSecurityPolicyConfig":{"enabled":false},"privateCluster":false,"privateClusterConfig":{"enablePrivateEndpoint":false,"enablePrivateNodes":false,"masterGlobalAccessConfig":{"enabled":false},"masterIpv4CidrBlock":"","peeringName":"","privateEndpoint":"","privateEndpointSubnetwork":"","publicEndpoint":""},"protectConfig":{"workloadConfig":{"auditMode":""},"workloadVulnerabilityMode":""},"releaseChannel":{"channel":""},"resourceLabels":{},"resourceUsageExportConfig":{"bigqueryDestination":{"datasetId":""},"consumptionMeteringConfig":{"enabled":false},"enableNetworkEgressMetering":false},"selfLink":"","servicesIpv4Cidr":"","shieldedNodes":{"enabled":false},"status":"","statusMessage":"","subnetwork":"","tpuConfig":{"enabled":false,"ipv4CidrBlock":"","useServiceNetworking":false},"tpuIpv4CidrBlock":"","verticalPodAutoscaling":{"enabled":false},"workloadAltsConfig":{"enableAlts":false},"workloadCertificates":{"enableCertificates":false},"workloadIdentityConfig":{"identityNamespace":"","identityProvider":"","workloadPool":""},"zone":""},"parent":"","projectId":"","zone":""}'
};

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 = @{ @"cluster": @{ @"addonsConfig": @{ @"cloudRunConfig": @{ @"disabled": @NO, @"loadBalancerType": @"" }, @"configConnectorConfig": @{ @"enabled": @NO }, @"dnsCacheConfig": @{ @"enabled": @NO }, @"gcePersistentDiskCsiDriverConfig": @{ @"enabled": @NO }, @"gcpFilestoreCsiDriverConfig": @{ @"enabled": @NO }, @"gkeBackupAgentConfig": @{ @"enabled": @NO }, @"horizontalPodAutoscaling": @{ @"disabled": @NO }, @"httpLoadBalancing": @{ @"disabled": @NO }, @"istioConfig": @{ @"auth": @"", @"disabled": @NO }, @"kalmConfig": @{ @"enabled": @NO }, @"kubernetesDashboard": @{ @"disabled": @NO }, @"networkPolicyConfig": @{ @"disabled": @NO } }, @"authenticatorGroupsConfig": @{ @"enabled": @NO, @"securityGroup": @"" }, @"autopilot": @{ @"enabled": @NO }, @"autoscaling": @{ @"autoprovisioningLocations": @[  ], @"autoprovisioningNodePoolDefaults": @{ @"bootDiskKmsKey": @"", @"diskSizeGb": @0, @"diskType": @"", @"imageType": @"", @"management": @{ @"autoRepair": @NO, @"autoUpgrade": @NO, @"upgradeOptions": @{ @"autoUpgradeStartTime": @"", @"description": @"" } }, @"minCpuPlatform": @"", @"oauthScopes": @[  ], @"serviceAccount": @"", @"shieldedInstanceConfig": @{ @"enableIntegrityMonitoring": @NO, @"enableSecureBoot": @NO }, @"upgradeSettings": @{ @"blueGreenSettings": @{ @"nodePoolSoakDuration": @"", @"standardRolloutPolicy": @{ @"batchNodeCount": @0, @"batchPercentage": @"", @"batchSoakDuration": @"" } }, @"maxSurge": @0, @"maxUnavailable": @0, @"strategy": @"" } }, @"autoscalingProfile": @"", @"enableNodeAutoprovisioning": @NO, @"resourceLimits": @[ @{ @"maximum": @"", @"minimum": @"", @"resourceType": @"" } ] }, @"binaryAuthorization": @{ @"enabled": @NO, @"evaluationMode": @"" }, @"clusterIpv4Cidr": @"", @"clusterTelemetry": @{ @"type": @"" }, @"conditions": @[ @{ @"canonicalCode": @"", @"code": @"", @"message": @"" } ], @"confidentialNodes": @{ @"enabled": @NO }, @"costManagementConfig": @{ @"enabled": @NO }, @"createTime": @"", @"currentMasterVersion": @"", @"currentNodeCount": @0, @"currentNodeVersion": @"", @"databaseEncryption": @{ @"keyName": @"", @"state": @"" }, @"defaultMaxPodsConstraint": @{ @"maxPodsPerNode": @"" }, @"description": @"", @"enableKubernetesAlpha": @NO, @"enableTpu": @NO, @"endpoint": @"", @"etag": @"", @"expireTime": @"", @"fleet": @{ @"membership": @"", @"preRegistered": @NO, @"project": @"" }, @"id": @"", @"identityServiceConfig": @{ @"enabled": @NO }, @"initialClusterVersion": @"", @"initialNodeCount": @0, @"instanceGroupUrls": @[  ], @"ipAllocationPolicy": @{ @"additionalPodRangesConfig": @{ @"podRangeNames": @[  ] }, @"allowRouteOverlap": @NO, @"clusterIpv4Cidr": @"", @"clusterIpv4CidrBlock": @"", @"clusterSecondaryRangeName": @"", @"createSubnetwork": @NO, @"ipv6AccessType": @"", @"nodeIpv4Cidr": @"", @"nodeIpv4CidrBlock": @"", @"podCidrOverprovisionConfig": @{ @"disable": @NO }, @"servicesIpv4Cidr": @"", @"servicesIpv4CidrBlock": @"", @"servicesIpv6CidrBlock": @"", @"servicesSecondaryRangeName": @"", @"stackType": @"", @"subnetIpv6CidrBlock": @"", @"subnetworkName": @"", @"tpuIpv4CidrBlock": @"", @"useIpAliases": @NO, @"useRoutes": @NO }, @"labelFingerprint": @"", @"legacyAbac": @{ @"enabled": @NO }, @"location": @"", @"locations": @[  ], @"loggingConfig": @{ @"componentConfig": @{ @"enableComponents": @[  ] } }, @"loggingService": @"", @"maintenancePolicy": @{ @"resourceVersion": @"", @"window": @{ @"dailyMaintenanceWindow": @{ @"duration": @"", @"startTime": @"" }, @"maintenanceExclusions": @{  }, @"recurringWindow": @{ @"recurrence": @"", @"window": @{ @"endTime": @"", @"maintenanceExclusionOptions": @{ @"scope": @"" }, @"startTime": @"" } } } }, @"master": @{  }, @"masterAuth": @{ @"clientCertificate": @"", @"clientCertificateConfig": @{ @"issueClientCertificate": @NO }, @"clientKey": @"", @"clusterCaCertificate": @"", @"password": @"", @"username": @"" }, @"masterAuthorizedNetworksConfig": @{ @"cidrBlocks": @[ @{ @"cidrBlock": @"", @"displayName": @"" } ], @"enabled": @NO, @"gcpPublicCidrsAccessEnabled": @NO }, @"masterIpv4CidrBlock": @"", @"meshCertificates": @{ @"enableCertificates": @NO }, @"monitoringConfig": @{ @"componentConfig": @{ @"enableComponents": @[  ] }, @"managedPrometheusConfig": @{ @"enabled": @NO } }, @"monitoringService": @"", @"name": @"", @"network": @"", @"networkConfig": @{ @"datapathProvider": @"", @"defaultSnatStatus": @{ @"disabled": @NO }, @"dnsConfig": @{ @"clusterDns": @"", @"clusterDnsDomain": @"", @"clusterDnsScope": @"" }, @"enableIntraNodeVisibility": @NO, @"enableL4ilbSubsetting": @NO, @"gatewayApiConfig": @{ @"channel": @"" }, @"network": @"", @"privateIpv6GoogleAccess": @"", @"serviceExternalIpsConfig": @{ @"enabled": @NO }, @"subnetwork": @"" }, @"networkPolicy": @{ @"enabled": @NO, @"provider": @"" }, @"nodeConfig": @{ @"accelerators": @[ @{ @"acceleratorCount": @"", @"acceleratorType": @"", @"gpuPartitionSize": @"", @"gpuSharingConfig": @{ @"gpuSharingStrategy": @"", @"maxSharedClientsPerGpu": @"" }, @"maxTimeSharedClientsPerGpu": @"" } ], @"advancedMachineFeatures": @{ @"threadsPerCore": @"" }, @"bootDiskKmsKey": @"", @"confidentialNodes": @{  }, @"diskSizeGb": @0, @"diskType": @"", @"ephemeralStorageConfig": @{ @"localSsdCount": @0 }, @"ephemeralStorageLocalSsdConfig": @{ @"localSsdCount": @0 }, @"fastSocket": @{ @"enabled": @NO }, @"gcfsConfig": @{ @"enabled": @NO }, @"gvnic": @{ @"enabled": @NO }, @"imageType": @"", @"kubeletConfig": @{ @"cpuCfsQuota": @NO, @"cpuCfsQuotaPeriod": @"", @"cpuManagerPolicy": @"", @"podPidsLimit": @"" }, @"labels": @{  }, @"linuxNodeConfig": @{ @"cgroupMode": @"", @"sysctls": @{  } }, @"localNvmeSsdBlockConfig": @{ @"localSsdCount": @0 }, @"localSsdCount": @0, @"loggingConfig": @{ @"variantConfig": @{ @"variant": @"" } }, @"machineType": @"", @"metadata": @{  }, @"minCpuPlatform": @"", @"nodeGroup": @"", @"oauthScopes": @[  ], @"preemptible": @NO, @"reservationAffinity": @{ @"consumeReservationType": @"", @"key": @"", @"values": @[  ] }, @"resourceLabels": @{  }, @"sandboxConfig": @{ @"sandboxType": @"", @"type": @"" }, @"serviceAccount": @"", @"shieldedInstanceConfig": @{  }, @"spot": @NO, @"tags": @[  ], @"taints": @[ @{ @"effect": @"", @"key": @"", @"value": @"" } ], @"windowsNodeConfig": @{ @"osVersion": @"" }, @"workloadMetadataConfig": @{ @"mode": @"", @"nodeMetadata": @"" } }, @"nodeIpv4CidrSize": @0, @"nodePoolAutoConfig": @{ @"networkTags": @{ @"tags": @[  ] } }, @"nodePoolDefaults": @{ @"nodeConfigDefaults": @{ @"gcfsConfig": @{  }, @"loggingConfig": @{  } } }, @"nodePools": @[ @{ @"autoscaling": @{ @"autoprovisioned": @NO, @"enabled": @NO, @"locationPolicy": @"", @"maxNodeCount": @0, @"minNodeCount": @0, @"totalMaxNodeCount": @0, @"totalMinNodeCount": @0 }, @"conditions": @[ @{  } ], @"config": @{  }, @"etag": @"", @"initialNodeCount": @0, @"instanceGroupUrls": @[  ], @"locations": @[  ], @"management": @{  }, @"maxPodsConstraint": @{  }, @"name": @"", @"networkConfig": @{ @"createPodRange": @NO, @"enablePrivateNodes": @NO, @"networkPerformanceConfig": @{ @"externalIpEgressBandwidthTier": @"", @"totalEgressBandwidthTier": @"" }, @"podCidrOverprovisionConfig": @{  }, @"podIpv4CidrBlock": @"", @"podRange": @"" }, @"placementPolicy": @{ @"type": @"" }, @"podIpv4CidrSize": @0, @"selfLink": @"", @"status": @"", @"statusMessage": @"", @"updateInfo": @{ @"blueGreenInfo": @{ @"blueInstanceGroupUrls": @[  ], @"bluePoolDeletionStartTime": @"", @"greenInstanceGroupUrls": @[  ], @"greenPoolVersion": @"", @"phase": @"" } }, @"upgradeSettings": @{  }, @"version": @"" } ], @"notificationConfig": @{ @"pubsub": @{ @"enabled": @NO, @"filter": @{ @"eventType": @[  ] }, @"topic": @"" } }, @"podSecurityPolicyConfig": @{ @"enabled": @NO }, @"privateCluster": @NO, @"privateClusterConfig": @{ @"enablePrivateEndpoint": @NO, @"enablePrivateNodes": @NO, @"masterGlobalAccessConfig": @{ @"enabled": @NO }, @"masterIpv4CidrBlock": @"", @"peeringName": @"", @"privateEndpoint": @"", @"privateEndpointSubnetwork": @"", @"publicEndpoint": @"" }, @"protectConfig": @{ @"workloadConfig": @{ @"auditMode": @"" }, @"workloadVulnerabilityMode": @"" }, @"releaseChannel": @{ @"channel": @"" }, @"resourceLabels": @{  }, @"resourceUsageExportConfig": @{ @"bigqueryDestination": @{ @"datasetId": @"" }, @"consumptionMeteringConfig": @{ @"enabled": @NO }, @"enableNetworkEgressMetering": @NO }, @"selfLink": @"", @"servicesIpv4Cidr": @"", @"shieldedNodes": @{ @"enabled": @NO }, @"status": @"", @"statusMessage": @"", @"subnetwork": @"", @"tpuConfig": @{ @"enabled": @NO, @"ipv4CidrBlock": @"", @"useServiceNetworking": @NO }, @"tpuIpv4CidrBlock": @"", @"verticalPodAutoscaling": @{ @"enabled": @NO }, @"workloadAltsConfig": @{ @"enableAlts": @NO }, @"workloadCertificates": @{ @"enableCertificates": @NO }, @"workloadIdentityConfig": @{ @"identityNamespace": @"", @"identityProvider": @"", @"workloadPool": @"" }, @"zone": @"" },
                              @"parent": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:parent/clusters"]
                                                       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}}/v1beta1/:parent/clusters" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:parent/clusters",
  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([
    'cluster' => [
        'addonsConfig' => [
                'cloudRunConfig' => [
                                'disabled' => null,
                                'loadBalancerType' => ''
                ],
                'configConnectorConfig' => [
                                'enabled' => null
                ],
                'dnsCacheConfig' => [
                                'enabled' => null
                ],
                'gcePersistentDiskCsiDriverConfig' => [
                                'enabled' => null
                ],
                'gcpFilestoreCsiDriverConfig' => [
                                'enabled' => null
                ],
                'gkeBackupAgentConfig' => [
                                'enabled' => null
                ],
                'horizontalPodAutoscaling' => [
                                'disabled' => null
                ],
                'httpLoadBalancing' => [
                                'disabled' => null
                ],
                'istioConfig' => [
                                'auth' => '',
                                'disabled' => null
                ],
                'kalmConfig' => [
                                'enabled' => null
                ],
                'kubernetesDashboard' => [
                                'disabled' => null
                ],
                'networkPolicyConfig' => [
                                'disabled' => null
                ]
        ],
        'authenticatorGroupsConfig' => [
                'enabled' => null,
                'securityGroup' => ''
        ],
        'autopilot' => [
                'enabled' => null
        ],
        'autoscaling' => [
                'autoprovisioningLocations' => [
                                
                ],
                'autoprovisioningNodePoolDefaults' => [
                                'bootDiskKmsKey' => '',
                                'diskSizeGb' => 0,
                                'diskType' => '',
                                'imageType' => '',
                                'management' => [
                                                                'autoRepair' => null,
                                                                'autoUpgrade' => null,
                                                                'upgradeOptions' => [
                                                                                                                                'autoUpgradeStartTime' => '',
                                                                                                                                'description' => ''
                                                                ]
                                ],
                                'minCpuPlatform' => '',
                                'oauthScopes' => [
                                                                
                                ],
                                'serviceAccount' => '',
                                'shieldedInstanceConfig' => [
                                                                'enableIntegrityMonitoring' => null,
                                                                'enableSecureBoot' => null
                                ],
                                'upgradeSettings' => [
                                                                'blueGreenSettings' => [
                                                                                                                                'nodePoolSoakDuration' => '',
                                                                                                                                'standardRolloutPolicy' => [
                                                                                                                                                                                                                                                                'batchNodeCount' => 0,
                                                                                                                                                                                                                                                                'batchPercentage' => '',
                                                                                                                                                                                                                                                                'batchSoakDuration' => ''
                                                                                                                                ]
                                                                ],
                                                                'maxSurge' => 0,
                                                                'maxUnavailable' => 0,
                                                                'strategy' => ''
                                ]
                ],
                'autoscalingProfile' => '',
                'enableNodeAutoprovisioning' => null,
                'resourceLimits' => [
                                [
                                                                'maximum' => '',
                                                                'minimum' => '',
                                                                'resourceType' => ''
                                ]
                ]
        ],
        'binaryAuthorization' => [
                'enabled' => null,
                'evaluationMode' => ''
        ],
        'clusterIpv4Cidr' => '',
        'clusterTelemetry' => [
                'type' => ''
        ],
        'conditions' => [
                [
                                'canonicalCode' => '',
                                'code' => '',
                                'message' => ''
                ]
        ],
        'confidentialNodes' => [
                'enabled' => null
        ],
        'costManagementConfig' => [
                'enabled' => null
        ],
        'createTime' => '',
        'currentMasterVersion' => '',
        'currentNodeCount' => 0,
        'currentNodeVersion' => '',
        'databaseEncryption' => [
                'keyName' => '',
                'state' => ''
        ],
        'defaultMaxPodsConstraint' => [
                'maxPodsPerNode' => ''
        ],
        'description' => '',
        'enableKubernetesAlpha' => null,
        'enableTpu' => null,
        'endpoint' => '',
        'etag' => '',
        'expireTime' => '',
        'fleet' => [
                'membership' => '',
                'preRegistered' => null,
                'project' => ''
        ],
        'id' => '',
        'identityServiceConfig' => [
                'enabled' => null
        ],
        'initialClusterVersion' => '',
        'initialNodeCount' => 0,
        'instanceGroupUrls' => [
                
        ],
        'ipAllocationPolicy' => [
                'additionalPodRangesConfig' => [
                                'podRangeNames' => [
                                                                
                                ]
                ],
                'allowRouteOverlap' => null,
                'clusterIpv4Cidr' => '',
                'clusterIpv4CidrBlock' => '',
                'clusterSecondaryRangeName' => '',
                'createSubnetwork' => null,
                'ipv6AccessType' => '',
                'nodeIpv4Cidr' => '',
                'nodeIpv4CidrBlock' => '',
                'podCidrOverprovisionConfig' => [
                                'disable' => null
                ],
                'servicesIpv4Cidr' => '',
                'servicesIpv4CidrBlock' => '',
                'servicesIpv6CidrBlock' => '',
                'servicesSecondaryRangeName' => '',
                'stackType' => '',
                'subnetIpv6CidrBlock' => '',
                'subnetworkName' => '',
                'tpuIpv4CidrBlock' => '',
                'useIpAliases' => null,
                'useRoutes' => null
        ],
        'labelFingerprint' => '',
        'legacyAbac' => [
                'enabled' => null
        ],
        'location' => '',
        'locations' => [
                
        ],
        'loggingConfig' => [
                'componentConfig' => [
                                'enableComponents' => [
                                                                
                                ]
                ]
        ],
        'loggingService' => '',
        'maintenancePolicy' => [
                'resourceVersion' => '',
                'window' => [
                                'dailyMaintenanceWindow' => [
                                                                'duration' => '',
                                                                'startTime' => ''
                                ],
                                'maintenanceExclusions' => [
                                                                
                                ],
                                'recurringWindow' => [
                                                                'recurrence' => '',
                                                                'window' => [
                                                                                                                                'endTime' => '',
                                                                                                                                'maintenanceExclusionOptions' => [
                                                                                                                                                                                                                                                                'scope' => ''
                                                                                                                                ],
                                                                                                                                'startTime' => ''
                                                                ]
                                ]
                ]
        ],
        'master' => [
                
        ],
        'masterAuth' => [
                'clientCertificate' => '',
                'clientCertificateConfig' => [
                                'issueClientCertificate' => null
                ],
                'clientKey' => '',
                'clusterCaCertificate' => '',
                'password' => '',
                'username' => ''
        ],
        'masterAuthorizedNetworksConfig' => [
                'cidrBlocks' => [
                                [
                                                                'cidrBlock' => '',
                                                                'displayName' => ''
                                ]
                ],
                'enabled' => null,
                'gcpPublicCidrsAccessEnabled' => null
        ],
        'masterIpv4CidrBlock' => '',
        'meshCertificates' => [
                'enableCertificates' => null
        ],
        'monitoringConfig' => [
                'componentConfig' => [
                                'enableComponents' => [
                                                                
                                ]
                ],
                'managedPrometheusConfig' => [
                                'enabled' => null
                ]
        ],
        'monitoringService' => '',
        'name' => '',
        'network' => '',
        'networkConfig' => [
                'datapathProvider' => '',
                'defaultSnatStatus' => [
                                'disabled' => null
                ],
                'dnsConfig' => [
                                'clusterDns' => '',
                                'clusterDnsDomain' => '',
                                'clusterDnsScope' => ''
                ],
                'enableIntraNodeVisibility' => null,
                'enableL4ilbSubsetting' => null,
                'gatewayApiConfig' => [
                                'channel' => ''
                ],
                'network' => '',
                'privateIpv6GoogleAccess' => '',
                'serviceExternalIpsConfig' => [
                                'enabled' => null
                ],
                'subnetwork' => ''
        ],
        'networkPolicy' => [
                'enabled' => null,
                'provider' => ''
        ],
        'nodeConfig' => [
                'accelerators' => [
                                [
                                                                'acceleratorCount' => '',
                                                                'acceleratorType' => '',
                                                                'gpuPartitionSize' => '',
                                                                'gpuSharingConfig' => [
                                                                                                                                'gpuSharingStrategy' => '',
                                                                                                                                'maxSharedClientsPerGpu' => ''
                                                                ],
                                                                'maxTimeSharedClientsPerGpu' => ''
                                ]
                ],
                'advancedMachineFeatures' => [
                                'threadsPerCore' => ''
                ],
                'bootDiskKmsKey' => '',
                'confidentialNodes' => [
                                
                ],
                'diskSizeGb' => 0,
                'diskType' => '',
                'ephemeralStorageConfig' => [
                                'localSsdCount' => 0
                ],
                'ephemeralStorageLocalSsdConfig' => [
                                'localSsdCount' => 0
                ],
                'fastSocket' => [
                                'enabled' => null
                ],
                'gcfsConfig' => [
                                'enabled' => null
                ],
                'gvnic' => [
                                'enabled' => null
                ],
                'imageType' => '',
                'kubeletConfig' => [
                                'cpuCfsQuota' => null,
                                'cpuCfsQuotaPeriod' => '',
                                'cpuManagerPolicy' => '',
                                'podPidsLimit' => ''
                ],
                'labels' => [
                                
                ],
                'linuxNodeConfig' => [
                                'cgroupMode' => '',
                                'sysctls' => [
                                                                
                                ]
                ],
                'localNvmeSsdBlockConfig' => [
                                'localSsdCount' => 0
                ],
                'localSsdCount' => 0,
                'loggingConfig' => [
                                'variantConfig' => [
                                                                'variant' => ''
                                ]
                ],
                'machineType' => '',
                'metadata' => [
                                
                ],
                'minCpuPlatform' => '',
                'nodeGroup' => '',
                'oauthScopes' => [
                                
                ],
                'preemptible' => null,
                'reservationAffinity' => [
                                'consumeReservationType' => '',
                                'key' => '',
                                'values' => [
                                                                
                                ]
                ],
                'resourceLabels' => [
                                
                ],
                'sandboxConfig' => [
                                'sandboxType' => '',
                                'type' => ''
                ],
                'serviceAccount' => '',
                'shieldedInstanceConfig' => [
                                
                ],
                'spot' => null,
                'tags' => [
                                
                ],
                'taints' => [
                                [
                                                                'effect' => '',
                                                                'key' => '',
                                                                'value' => ''
                                ]
                ],
                'windowsNodeConfig' => [
                                'osVersion' => ''
                ],
                'workloadMetadataConfig' => [
                                'mode' => '',
                                'nodeMetadata' => ''
                ]
        ],
        'nodeIpv4CidrSize' => 0,
        'nodePoolAutoConfig' => [
                'networkTags' => [
                                'tags' => [
                                                                
                                ]
                ]
        ],
        'nodePoolDefaults' => [
                'nodeConfigDefaults' => [
                                'gcfsConfig' => [
                                                                
                                ],
                                'loggingConfig' => [
                                                                
                                ]
                ]
        ],
        'nodePools' => [
                [
                                'autoscaling' => [
                                                                'autoprovisioned' => null,
                                                                'enabled' => null,
                                                                'locationPolicy' => '',
                                                                'maxNodeCount' => 0,
                                                                'minNodeCount' => 0,
                                                                'totalMaxNodeCount' => 0,
                                                                'totalMinNodeCount' => 0
                                ],
                                'conditions' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'config' => [
                                                                
                                ],
                                'etag' => '',
                                'initialNodeCount' => 0,
                                'instanceGroupUrls' => [
                                                                
                                ],
                                'locations' => [
                                                                
                                ],
                                'management' => [
                                                                
                                ],
                                'maxPodsConstraint' => [
                                                                
                                ],
                                'name' => '',
                                'networkConfig' => [
                                                                'createPodRange' => null,
                                                                'enablePrivateNodes' => null,
                                                                'networkPerformanceConfig' => [
                                                                                                                                'externalIpEgressBandwidthTier' => '',
                                                                                                                                'totalEgressBandwidthTier' => ''
                                                                ],
                                                                'podCidrOverprovisionConfig' => [
                                                                                                                                
                                                                ],
                                                                'podIpv4CidrBlock' => '',
                                                                'podRange' => ''
                                ],
                                'placementPolicy' => [
                                                                'type' => ''
                                ],
                                'podIpv4CidrSize' => 0,
                                'selfLink' => '',
                                'status' => '',
                                'statusMessage' => '',
                                'updateInfo' => [
                                                                'blueGreenInfo' => [
                                                                                                                                'blueInstanceGroupUrls' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'bluePoolDeletionStartTime' => '',
                                                                                                                                'greenInstanceGroupUrls' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'greenPoolVersion' => '',
                                                                                                                                'phase' => ''
                                                                ]
                                ],
                                'upgradeSettings' => [
                                                                
                                ],
                                'version' => ''
                ]
        ],
        'notificationConfig' => [
                'pubsub' => [
                                'enabled' => null,
                                'filter' => [
                                                                'eventType' => [
                                                                                                                                
                                                                ]
                                ],
                                'topic' => ''
                ]
        ],
        'podSecurityPolicyConfig' => [
                'enabled' => null
        ],
        'privateCluster' => null,
        'privateClusterConfig' => [
                'enablePrivateEndpoint' => null,
                'enablePrivateNodes' => null,
                'masterGlobalAccessConfig' => [
                                'enabled' => null
                ],
                'masterIpv4CidrBlock' => '',
                'peeringName' => '',
                'privateEndpoint' => '',
                'privateEndpointSubnetwork' => '',
                'publicEndpoint' => ''
        ],
        'protectConfig' => [
                'workloadConfig' => [
                                'auditMode' => ''
                ],
                'workloadVulnerabilityMode' => ''
        ],
        'releaseChannel' => [
                'channel' => ''
        ],
        'resourceLabels' => [
                
        ],
        'resourceUsageExportConfig' => [
                'bigqueryDestination' => [
                                'datasetId' => ''
                ],
                'consumptionMeteringConfig' => [
                                'enabled' => null
                ],
                'enableNetworkEgressMetering' => null
        ],
        'selfLink' => '',
        'servicesIpv4Cidr' => '',
        'shieldedNodes' => [
                'enabled' => null
        ],
        'status' => '',
        'statusMessage' => '',
        'subnetwork' => '',
        'tpuConfig' => [
                'enabled' => null,
                'ipv4CidrBlock' => '',
                'useServiceNetworking' => null
        ],
        'tpuIpv4CidrBlock' => '',
        'verticalPodAutoscaling' => [
                'enabled' => null
        ],
        'workloadAltsConfig' => [
                'enableAlts' => null
        ],
        'workloadCertificates' => [
                'enableCertificates' => null
        ],
        'workloadIdentityConfig' => [
                'identityNamespace' => '',
                'identityProvider' => '',
                'workloadPool' => ''
        ],
        'zone' => ''
    ],
    'parent' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:parent/clusters', [
  'body' => '{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cluster' => [
    'addonsConfig' => [
        'cloudRunConfig' => [
                'disabled' => null,
                'loadBalancerType' => ''
        ],
        'configConnectorConfig' => [
                'enabled' => null
        ],
        'dnsCacheConfig' => [
                'enabled' => null
        ],
        'gcePersistentDiskCsiDriverConfig' => [
                'enabled' => null
        ],
        'gcpFilestoreCsiDriverConfig' => [
                'enabled' => null
        ],
        'gkeBackupAgentConfig' => [
                'enabled' => null
        ],
        'horizontalPodAutoscaling' => [
                'disabled' => null
        ],
        'httpLoadBalancing' => [
                'disabled' => null
        ],
        'istioConfig' => [
                'auth' => '',
                'disabled' => null
        ],
        'kalmConfig' => [
                'enabled' => null
        ],
        'kubernetesDashboard' => [
                'disabled' => null
        ],
        'networkPolicyConfig' => [
                'disabled' => null
        ]
    ],
    'authenticatorGroupsConfig' => [
        'enabled' => null,
        'securityGroup' => ''
    ],
    'autopilot' => [
        'enabled' => null
    ],
    'autoscaling' => [
        'autoprovisioningLocations' => [
                
        ],
        'autoprovisioningNodePoolDefaults' => [
                'bootDiskKmsKey' => '',
                'diskSizeGb' => 0,
                'diskType' => '',
                'imageType' => '',
                'management' => [
                                'autoRepair' => null,
                                'autoUpgrade' => null,
                                'upgradeOptions' => [
                                                                'autoUpgradeStartTime' => '',
                                                                'description' => ''
                                ]
                ],
                'minCpuPlatform' => '',
                'oauthScopes' => [
                                
                ],
                'serviceAccount' => '',
                'shieldedInstanceConfig' => [
                                'enableIntegrityMonitoring' => null,
                                'enableSecureBoot' => null
                ],
                'upgradeSettings' => [
                                'blueGreenSettings' => [
                                                                'nodePoolSoakDuration' => '',
                                                                'standardRolloutPolicy' => [
                                                                                                                                'batchNodeCount' => 0,
                                                                                                                                'batchPercentage' => '',
                                                                                                                                'batchSoakDuration' => ''
                                                                ]
                                ],
                                'maxSurge' => 0,
                                'maxUnavailable' => 0,
                                'strategy' => ''
                ]
        ],
        'autoscalingProfile' => '',
        'enableNodeAutoprovisioning' => null,
        'resourceLimits' => [
                [
                                'maximum' => '',
                                'minimum' => '',
                                'resourceType' => ''
                ]
        ]
    ],
    'binaryAuthorization' => [
        'enabled' => null,
        'evaluationMode' => ''
    ],
    'clusterIpv4Cidr' => '',
    'clusterTelemetry' => [
        'type' => ''
    ],
    'conditions' => [
        [
                'canonicalCode' => '',
                'code' => '',
                'message' => ''
        ]
    ],
    'confidentialNodes' => [
        'enabled' => null
    ],
    'costManagementConfig' => [
        'enabled' => null
    ],
    'createTime' => '',
    'currentMasterVersion' => '',
    'currentNodeCount' => 0,
    'currentNodeVersion' => '',
    'databaseEncryption' => [
        'keyName' => '',
        'state' => ''
    ],
    'defaultMaxPodsConstraint' => [
        'maxPodsPerNode' => ''
    ],
    'description' => '',
    'enableKubernetesAlpha' => null,
    'enableTpu' => null,
    'endpoint' => '',
    'etag' => '',
    'expireTime' => '',
    'fleet' => [
        'membership' => '',
        'preRegistered' => null,
        'project' => ''
    ],
    'id' => '',
    'identityServiceConfig' => [
        'enabled' => null
    ],
    'initialClusterVersion' => '',
    'initialNodeCount' => 0,
    'instanceGroupUrls' => [
        
    ],
    'ipAllocationPolicy' => [
        'additionalPodRangesConfig' => [
                'podRangeNames' => [
                                
                ]
        ],
        'allowRouteOverlap' => null,
        'clusterIpv4Cidr' => '',
        'clusterIpv4CidrBlock' => '',
        'clusterSecondaryRangeName' => '',
        'createSubnetwork' => null,
        'ipv6AccessType' => '',
        'nodeIpv4Cidr' => '',
        'nodeIpv4CidrBlock' => '',
        'podCidrOverprovisionConfig' => [
                'disable' => null
        ],
        'servicesIpv4Cidr' => '',
        'servicesIpv4CidrBlock' => '',
        'servicesIpv6CidrBlock' => '',
        'servicesSecondaryRangeName' => '',
        'stackType' => '',
        'subnetIpv6CidrBlock' => '',
        'subnetworkName' => '',
        'tpuIpv4CidrBlock' => '',
        'useIpAliases' => null,
        'useRoutes' => null
    ],
    'labelFingerprint' => '',
    'legacyAbac' => [
        'enabled' => null
    ],
    'location' => '',
    'locations' => [
        
    ],
    'loggingConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ]
    ],
    'loggingService' => '',
    'maintenancePolicy' => [
        'resourceVersion' => '',
        'window' => [
                'dailyMaintenanceWindow' => [
                                'duration' => '',
                                'startTime' => ''
                ],
                'maintenanceExclusions' => [
                                
                ],
                'recurringWindow' => [
                                'recurrence' => '',
                                'window' => [
                                                                'endTime' => '',
                                                                'maintenanceExclusionOptions' => [
                                                                                                                                'scope' => ''
                                                                ],
                                                                'startTime' => ''
                                ]
                ]
        ]
    ],
    'master' => [
        
    ],
    'masterAuth' => [
        'clientCertificate' => '',
        'clientCertificateConfig' => [
                'issueClientCertificate' => null
        ],
        'clientKey' => '',
        'clusterCaCertificate' => '',
        'password' => '',
        'username' => ''
    ],
    'masterAuthorizedNetworksConfig' => [
        'cidrBlocks' => [
                [
                                'cidrBlock' => '',
                                'displayName' => ''
                ]
        ],
        'enabled' => null,
        'gcpPublicCidrsAccessEnabled' => null
    ],
    'masterIpv4CidrBlock' => '',
    'meshCertificates' => [
        'enableCertificates' => null
    ],
    'monitoringConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ],
        'managedPrometheusConfig' => [
                'enabled' => null
        ]
    ],
    'monitoringService' => '',
    'name' => '',
    'network' => '',
    'networkConfig' => [
        'datapathProvider' => '',
        'defaultSnatStatus' => [
                'disabled' => null
        ],
        'dnsConfig' => [
                'clusterDns' => '',
                'clusterDnsDomain' => '',
                'clusterDnsScope' => ''
        ],
        'enableIntraNodeVisibility' => null,
        'enableL4ilbSubsetting' => null,
        'gatewayApiConfig' => [
                'channel' => ''
        ],
        'network' => '',
        'privateIpv6GoogleAccess' => '',
        'serviceExternalIpsConfig' => [
                'enabled' => null
        ],
        'subnetwork' => ''
    ],
    'networkPolicy' => [
        'enabled' => null,
        'provider' => ''
    ],
    'nodeConfig' => [
        'accelerators' => [
                [
                                'acceleratorCount' => '',
                                'acceleratorType' => '',
                                'gpuPartitionSize' => '',
                                'gpuSharingConfig' => [
                                                                'gpuSharingStrategy' => '',
                                                                'maxSharedClientsPerGpu' => ''
                                ],
                                'maxTimeSharedClientsPerGpu' => ''
                ]
        ],
        'advancedMachineFeatures' => [
                'threadsPerCore' => ''
        ],
        'bootDiskKmsKey' => '',
        'confidentialNodes' => [
                
        ],
        'diskSizeGb' => 0,
        'diskType' => '',
        'ephemeralStorageConfig' => [
                'localSsdCount' => 0
        ],
        'ephemeralStorageLocalSsdConfig' => [
                'localSsdCount' => 0
        ],
        'fastSocket' => [
                'enabled' => null
        ],
        'gcfsConfig' => [
                'enabled' => null
        ],
        'gvnic' => [
                'enabled' => null
        ],
        'imageType' => '',
        'kubeletConfig' => [
                'cpuCfsQuota' => null,
                'cpuCfsQuotaPeriod' => '',
                'cpuManagerPolicy' => '',
                'podPidsLimit' => ''
        ],
        'labels' => [
                
        ],
        'linuxNodeConfig' => [
                'cgroupMode' => '',
                'sysctls' => [
                                
                ]
        ],
        'localNvmeSsdBlockConfig' => [
                'localSsdCount' => 0
        ],
        'localSsdCount' => 0,
        'loggingConfig' => [
                'variantConfig' => [
                                'variant' => ''
                ]
        ],
        'machineType' => '',
        'metadata' => [
                
        ],
        'minCpuPlatform' => '',
        'nodeGroup' => '',
        'oauthScopes' => [
                
        ],
        'preemptible' => null,
        'reservationAffinity' => [
                'consumeReservationType' => '',
                'key' => '',
                'values' => [
                                
                ]
        ],
        'resourceLabels' => [
                
        ],
        'sandboxConfig' => [
                'sandboxType' => '',
                'type' => ''
        ],
        'serviceAccount' => '',
        'shieldedInstanceConfig' => [
                
        ],
        'spot' => null,
        'tags' => [
                
        ],
        'taints' => [
                [
                                'effect' => '',
                                'key' => '',
                                'value' => ''
                ]
        ],
        'windowsNodeConfig' => [
                'osVersion' => ''
        ],
        'workloadMetadataConfig' => [
                'mode' => '',
                'nodeMetadata' => ''
        ]
    ],
    'nodeIpv4CidrSize' => 0,
    'nodePoolAutoConfig' => [
        'networkTags' => [
                'tags' => [
                                
                ]
        ]
    ],
    'nodePoolDefaults' => [
        'nodeConfigDefaults' => [
                'gcfsConfig' => [
                                
                ],
                'loggingConfig' => [
                                
                ]
        ]
    ],
    'nodePools' => [
        [
                'autoscaling' => [
                                'autoprovisioned' => null,
                                'enabled' => null,
                                'locationPolicy' => '',
                                'maxNodeCount' => 0,
                                'minNodeCount' => 0,
                                'totalMaxNodeCount' => 0,
                                'totalMinNodeCount' => 0
                ],
                'conditions' => [
                                [
                                                                
                                ]
                ],
                'config' => [
                                
                ],
                'etag' => '',
                'initialNodeCount' => 0,
                'instanceGroupUrls' => [
                                
                ],
                'locations' => [
                                
                ],
                'management' => [
                                
                ],
                'maxPodsConstraint' => [
                                
                ],
                'name' => '',
                'networkConfig' => [
                                'createPodRange' => null,
                                'enablePrivateNodes' => null,
                                'networkPerformanceConfig' => [
                                                                'externalIpEgressBandwidthTier' => '',
                                                                'totalEgressBandwidthTier' => ''
                                ],
                                'podCidrOverprovisionConfig' => [
                                                                
                                ],
                                'podIpv4CidrBlock' => '',
                                'podRange' => ''
                ],
                'placementPolicy' => [
                                'type' => ''
                ],
                'podIpv4CidrSize' => 0,
                'selfLink' => '',
                'status' => '',
                'statusMessage' => '',
                'updateInfo' => [
                                'blueGreenInfo' => [
                                                                'blueInstanceGroupUrls' => [
                                                                                                                                
                                                                ],
                                                                'bluePoolDeletionStartTime' => '',
                                                                'greenInstanceGroupUrls' => [
                                                                                                                                
                                                                ],
                                                                'greenPoolVersion' => '',
                                                                'phase' => ''
                                ]
                ],
                'upgradeSettings' => [
                                
                ],
                'version' => ''
        ]
    ],
    'notificationConfig' => [
        'pubsub' => [
                'enabled' => null,
                'filter' => [
                                'eventType' => [
                                                                
                                ]
                ],
                'topic' => ''
        ]
    ],
    'podSecurityPolicyConfig' => [
        'enabled' => null
    ],
    'privateCluster' => null,
    'privateClusterConfig' => [
        'enablePrivateEndpoint' => null,
        'enablePrivateNodes' => null,
        'masterGlobalAccessConfig' => [
                'enabled' => null
        ],
        'masterIpv4CidrBlock' => '',
        'peeringName' => '',
        'privateEndpoint' => '',
        'privateEndpointSubnetwork' => '',
        'publicEndpoint' => ''
    ],
    'protectConfig' => [
        'workloadConfig' => [
                'auditMode' => ''
        ],
        'workloadVulnerabilityMode' => ''
    ],
    'releaseChannel' => [
        'channel' => ''
    ],
    'resourceLabels' => [
        
    ],
    'resourceUsageExportConfig' => [
        'bigqueryDestination' => [
                'datasetId' => ''
        ],
        'consumptionMeteringConfig' => [
                'enabled' => null
        ],
        'enableNetworkEgressMetering' => null
    ],
    'selfLink' => '',
    'servicesIpv4Cidr' => '',
    'shieldedNodes' => [
        'enabled' => null
    ],
    'status' => '',
    'statusMessage' => '',
    'subnetwork' => '',
    'tpuConfig' => [
        'enabled' => null,
        'ipv4CidrBlock' => '',
        'useServiceNetworking' => null
    ],
    'tpuIpv4CidrBlock' => '',
    'verticalPodAutoscaling' => [
        'enabled' => null
    ],
    'workloadAltsConfig' => [
        'enableAlts' => null
    ],
    'workloadCertificates' => [
        'enableCertificates' => null
    ],
    'workloadIdentityConfig' => [
        'identityNamespace' => '',
        'identityProvider' => '',
        'workloadPool' => ''
    ],
    'zone' => ''
  ],
  'parent' => '',
  'projectId' => '',
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cluster' => [
    'addonsConfig' => [
        'cloudRunConfig' => [
                'disabled' => null,
                'loadBalancerType' => ''
        ],
        'configConnectorConfig' => [
                'enabled' => null
        ],
        'dnsCacheConfig' => [
                'enabled' => null
        ],
        'gcePersistentDiskCsiDriverConfig' => [
                'enabled' => null
        ],
        'gcpFilestoreCsiDriverConfig' => [
                'enabled' => null
        ],
        'gkeBackupAgentConfig' => [
                'enabled' => null
        ],
        'horizontalPodAutoscaling' => [
                'disabled' => null
        ],
        'httpLoadBalancing' => [
                'disabled' => null
        ],
        'istioConfig' => [
                'auth' => '',
                'disabled' => null
        ],
        'kalmConfig' => [
                'enabled' => null
        ],
        'kubernetesDashboard' => [
                'disabled' => null
        ],
        'networkPolicyConfig' => [
                'disabled' => null
        ]
    ],
    'authenticatorGroupsConfig' => [
        'enabled' => null,
        'securityGroup' => ''
    ],
    'autopilot' => [
        'enabled' => null
    ],
    'autoscaling' => [
        'autoprovisioningLocations' => [
                
        ],
        'autoprovisioningNodePoolDefaults' => [
                'bootDiskKmsKey' => '',
                'diskSizeGb' => 0,
                'diskType' => '',
                'imageType' => '',
                'management' => [
                                'autoRepair' => null,
                                'autoUpgrade' => null,
                                'upgradeOptions' => [
                                                                'autoUpgradeStartTime' => '',
                                                                'description' => ''
                                ]
                ],
                'minCpuPlatform' => '',
                'oauthScopes' => [
                                
                ],
                'serviceAccount' => '',
                'shieldedInstanceConfig' => [
                                'enableIntegrityMonitoring' => null,
                                'enableSecureBoot' => null
                ],
                'upgradeSettings' => [
                                'blueGreenSettings' => [
                                                                'nodePoolSoakDuration' => '',
                                                                'standardRolloutPolicy' => [
                                                                                                                                'batchNodeCount' => 0,
                                                                                                                                'batchPercentage' => '',
                                                                                                                                'batchSoakDuration' => ''
                                                                ]
                                ],
                                'maxSurge' => 0,
                                'maxUnavailable' => 0,
                                'strategy' => ''
                ]
        ],
        'autoscalingProfile' => '',
        'enableNodeAutoprovisioning' => null,
        'resourceLimits' => [
                [
                                'maximum' => '',
                                'minimum' => '',
                                'resourceType' => ''
                ]
        ]
    ],
    'binaryAuthorization' => [
        'enabled' => null,
        'evaluationMode' => ''
    ],
    'clusterIpv4Cidr' => '',
    'clusterTelemetry' => [
        'type' => ''
    ],
    'conditions' => [
        [
                'canonicalCode' => '',
                'code' => '',
                'message' => ''
        ]
    ],
    'confidentialNodes' => [
        'enabled' => null
    ],
    'costManagementConfig' => [
        'enabled' => null
    ],
    'createTime' => '',
    'currentMasterVersion' => '',
    'currentNodeCount' => 0,
    'currentNodeVersion' => '',
    'databaseEncryption' => [
        'keyName' => '',
        'state' => ''
    ],
    'defaultMaxPodsConstraint' => [
        'maxPodsPerNode' => ''
    ],
    'description' => '',
    'enableKubernetesAlpha' => null,
    'enableTpu' => null,
    'endpoint' => '',
    'etag' => '',
    'expireTime' => '',
    'fleet' => [
        'membership' => '',
        'preRegistered' => null,
        'project' => ''
    ],
    'id' => '',
    'identityServiceConfig' => [
        'enabled' => null
    ],
    'initialClusterVersion' => '',
    'initialNodeCount' => 0,
    'instanceGroupUrls' => [
        
    ],
    'ipAllocationPolicy' => [
        'additionalPodRangesConfig' => [
                'podRangeNames' => [
                                
                ]
        ],
        'allowRouteOverlap' => null,
        'clusterIpv4Cidr' => '',
        'clusterIpv4CidrBlock' => '',
        'clusterSecondaryRangeName' => '',
        'createSubnetwork' => null,
        'ipv6AccessType' => '',
        'nodeIpv4Cidr' => '',
        'nodeIpv4CidrBlock' => '',
        'podCidrOverprovisionConfig' => [
                'disable' => null
        ],
        'servicesIpv4Cidr' => '',
        'servicesIpv4CidrBlock' => '',
        'servicesIpv6CidrBlock' => '',
        'servicesSecondaryRangeName' => '',
        'stackType' => '',
        'subnetIpv6CidrBlock' => '',
        'subnetworkName' => '',
        'tpuIpv4CidrBlock' => '',
        'useIpAliases' => null,
        'useRoutes' => null
    ],
    'labelFingerprint' => '',
    'legacyAbac' => [
        'enabled' => null
    ],
    'location' => '',
    'locations' => [
        
    ],
    'loggingConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ]
    ],
    'loggingService' => '',
    'maintenancePolicy' => [
        'resourceVersion' => '',
        'window' => [
                'dailyMaintenanceWindow' => [
                                'duration' => '',
                                'startTime' => ''
                ],
                'maintenanceExclusions' => [
                                
                ],
                'recurringWindow' => [
                                'recurrence' => '',
                                'window' => [
                                                                'endTime' => '',
                                                                'maintenanceExclusionOptions' => [
                                                                                                                                'scope' => ''
                                                                ],
                                                                'startTime' => ''
                                ]
                ]
        ]
    ],
    'master' => [
        
    ],
    'masterAuth' => [
        'clientCertificate' => '',
        'clientCertificateConfig' => [
                'issueClientCertificate' => null
        ],
        'clientKey' => '',
        'clusterCaCertificate' => '',
        'password' => '',
        'username' => ''
    ],
    'masterAuthorizedNetworksConfig' => [
        'cidrBlocks' => [
                [
                                'cidrBlock' => '',
                                'displayName' => ''
                ]
        ],
        'enabled' => null,
        'gcpPublicCidrsAccessEnabled' => null
    ],
    'masterIpv4CidrBlock' => '',
    'meshCertificates' => [
        'enableCertificates' => null
    ],
    'monitoringConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ],
        'managedPrometheusConfig' => [
                'enabled' => null
        ]
    ],
    'monitoringService' => '',
    'name' => '',
    'network' => '',
    'networkConfig' => [
        'datapathProvider' => '',
        'defaultSnatStatus' => [
                'disabled' => null
        ],
        'dnsConfig' => [
                'clusterDns' => '',
                'clusterDnsDomain' => '',
                'clusterDnsScope' => ''
        ],
        'enableIntraNodeVisibility' => null,
        'enableL4ilbSubsetting' => null,
        'gatewayApiConfig' => [
                'channel' => ''
        ],
        'network' => '',
        'privateIpv6GoogleAccess' => '',
        'serviceExternalIpsConfig' => [
                'enabled' => null
        ],
        'subnetwork' => ''
    ],
    'networkPolicy' => [
        'enabled' => null,
        'provider' => ''
    ],
    'nodeConfig' => [
        'accelerators' => [
                [
                                'acceleratorCount' => '',
                                'acceleratorType' => '',
                                'gpuPartitionSize' => '',
                                'gpuSharingConfig' => [
                                                                'gpuSharingStrategy' => '',
                                                                'maxSharedClientsPerGpu' => ''
                                ],
                                'maxTimeSharedClientsPerGpu' => ''
                ]
        ],
        'advancedMachineFeatures' => [
                'threadsPerCore' => ''
        ],
        'bootDiskKmsKey' => '',
        'confidentialNodes' => [
                
        ],
        'diskSizeGb' => 0,
        'diskType' => '',
        'ephemeralStorageConfig' => [
                'localSsdCount' => 0
        ],
        'ephemeralStorageLocalSsdConfig' => [
                'localSsdCount' => 0
        ],
        'fastSocket' => [
                'enabled' => null
        ],
        'gcfsConfig' => [
                'enabled' => null
        ],
        'gvnic' => [
                'enabled' => null
        ],
        'imageType' => '',
        'kubeletConfig' => [
                'cpuCfsQuota' => null,
                'cpuCfsQuotaPeriod' => '',
                'cpuManagerPolicy' => '',
                'podPidsLimit' => ''
        ],
        'labels' => [
                
        ],
        'linuxNodeConfig' => [
                'cgroupMode' => '',
                'sysctls' => [
                                
                ]
        ],
        'localNvmeSsdBlockConfig' => [
                'localSsdCount' => 0
        ],
        'localSsdCount' => 0,
        'loggingConfig' => [
                'variantConfig' => [
                                'variant' => ''
                ]
        ],
        'machineType' => '',
        'metadata' => [
                
        ],
        'minCpuPlatform' => '',
        'nodeGroup' => '',
        'oauthScopes' => [
                
        ],
        'preemptible' => null,
        'reservationAffinity' => [
                'consumeReservationType' => '',
                'key' => '',
                'values' => [
                                
                ]
        ],
        'resourceLabels' => [
                
        ],
        'sandboxConfig' => [
                'sandboxType' => '',
                'type' => ''
        ],
        'serviceAccount' => '',
        'shieldedInstanceConfig' => [
                
        ],
        'spot' => null,
        'tags' => [
                
        ],
        'taints' => [
                [
                                'effect' => '',
                                'key' => '',
                                'value' => ''
                ]
        ],
        'windowsNodeConfig' => [
                'osVersion' => ''
        ],
        'workloadMetadataConfig' => [
                'mode' => '',
                'nodeMetadata' => ''
        ]
    ],
    'nodeIpv4CidrSize' => 0,
    'nodePoolAutoConfig' => [
        'networkTags' => [
                'tags' => [
                                
                ]
        ]
    ],
    'nodePoolDefaults' => [
        'nodeConfigDefaults' => [
                'gcfsConfig' => [
                                
                ],
                'loggingConfig' => [
                                
                ]
        ]
    ],
    'nodePools' => [
        [
                'autoscaling' => [
                                'autoprovisioned' => null,
                                'enabled' => null,
                                'locationPolicy' => '',
                                'maxNodeCount' => 0,
                                'minNodeCount' => 0,
                                'totalMaxNodeCount' => 0,
                                'totalMinNodeCount' => 0
                ],
                'conditions' => [
                                [
                                                                
                                ]
                ],
                'config' => [
                                
                ],
                'etag' => '',
                'initialNodeCount' => 0,
                'instanceGroupUrls' => [
                                
                ],
                'locations' => [
                                
                ],
                'management' => [
                                
                ],
                'maxPodsConstraint' => [
                                
                ],
                'name' => '',
                'networkConfig' => [
                                'createPodRange' => null,
                                'enablePrivateNodes' => null,
                                'networkPerformanceConfig' => [
                                                                'externalIpEgressBandwidthTier' => '',
                                                                'totalEgressBandwidthTier' => ''
                                ],
                                'podCidrOverprovisionConfig' => [
                                                                
                                ],
                                'podIpv4CidrBlock' => '',
                                'podRange' => ''
                ],
                'placementPolicy' => [
                                'type' => ''
                ],
                'podIpv4CidrSize' => 0,
                'selfLink' => '',
                'status' => '',
                'statusMessage' => '',
                'updateInfo' => [
                                'blueGreenInfo' => [
                                                                'blueInstanceGroupUrls' => [
                                                                                                                                
                                                                ],
                                                                'bluePoolDeletionStartTime' => '',
                                                                'greenInstanceGroupUrls' => [
                                                                                                                                
                                                                ],
                                                                'greenPoolVersion' => '',
                                                                'phase' => ''
                                ]
                ],
                'upgradeSettings' => [
                                
                ],
                'version' => ''
        ]
    ],
    'notificationConfig' => [
        'pubsub' => [
                'enabled' => null,
                'filter' => [
                                'eventType' => [
                                                                
                                ]
                ],
                'topic' => ''
        ]
    ],
    'podSecurityPolicyConfig' => [
        'enabled' => null
    ],
    'privateCluster' => null,
    'privateClusterConfig' => [
        'enablePrivateEndpoint' => null,
        'enablePrivateNodes' => null,
        'masterGlobalAccessConfig' => [
                'enabled' => null
        ],
        'masterIpv4CidrBlock' => '',
        'peeringName' => '',
        'privateEndpoint' => '',
        'privateEndpointSubnetwork' => '',
        'publicEndpoint' => ''
    ],
    'protectConfig' => [
        'workloadConfig' => [
                'auditMode' => ''
        ],
        'workloadVulnerabilityMode' => ''
    ],
    'releaseChannel' => [
        'channel' => ''
    ],
    'resourceLabels' => [
        
    ],
    'resourceUsageExportConfig' => [
        'bigqueryDestination' => [
                'datasetId' => ''
        ],
        'consumptionMeteringConfig' => [
                'enabled' => null
        ],
        'enableNetworkEgressMetering' => null
    ],
    'selfLink' => '',
    'servicesIpv4Cidr' => '',
    'shieldedNodes' => [
        'enabled' => null
    ],
    'status' => '',
    'statusMessage' => '',
    'subnetwork' => '',
    'tpuConfig' => [
        'enabled' => null,
        'ipv4CidrBlock' => '',
        'useServiceNetworking' => null
    ],
    'tpuIpv4CidrBlock' => '',
    'verticalPodAutoscaling' => [
        'enabled' => null
    ],
    'workloadAltsConfig' => [
        'enableAlts' => null
    ],
    'workloadCertificates' => [
        'enableCertificates' => null
    ],
    'workloadIdentityConfig' => [
        'identityNamespace' => '',
        'identityProvider' => '',
        'workloadPool' => ''
    ],
    'zone' => ''
  ],
  'parent' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:parent/clusters');
$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}}/v1beta1/:parent/clusters' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent/clusters' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
import http.client

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

payload = "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:parent/clusters", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:parent/clusters"

payload = {
    "cluster": {
        "addonsConfig": {
            "cloudRunConfig": {
                "disabled": False,
                "loadBalancerType": ""
            },
            "configConnectorConfig": { "enabled": False },
            "dnsCacheConfig": { "enabled": False },
            "gcePersistentDiskCsiDriverConfig": { "enabled": False },
            "gcpFilestoreCsiDriverConfig": { "enabled": False },
            "gkeBackupAgentConfig": { "enabled": False },
            "horizontalPodAutoscaling": { "disabled": False },
            "httpLoadBalancing": { "disabled": False },
            "istioConfig": {
                "auth": "",
                "disabled": False
            },
            "kalmConfig": { "enabled": False },
            "kubernetesDashboard": { "disabled": False },
            "networkPolicyConfig": { "disabled": False }
        },
        "authenticatorGroupsConfig": {
            "enabled": False,
            "securityGroup": ""
        },
        "autopilot": { "enabled": False },
        "autoscaling": {
            "autoprovisioningLocations": [],
            "autoprovisioningNodePoolDefaults": {
                "bootDiskKmsKey": "",
                "diskSizeGb": 0,
                "diskType": "",
                "imageType": "",
                "management": {
                    "autoRepair": False,
                    "autoUpgrade": False,
                    "upgradeOptions": {
                        "autoUpgradeStartTime": "",
                        "description": ""
                    }
                },
                "minCpuPlatform": "",
                "oauthScopes": [],
                "serviceAccount": "",
                "shieldedInstanceConfig": {
                    "enableIntegrityMonitoring": False,
                    "enableSecureBoot": False
                },
                "upgradeSettings": {
                    "blueGreenSettings": {
                        "nodePoolSoakDuration": "",
                        "standardRolloutPolicy": {
                            "batchNodeCount": 0,
                            "batchPercentage": "",
                            "batchSoakDuration": ""
                        }
                    },
                    "maxSurge": 0,
                    "maxUnavailable": 0,
                    "strategy": ""
                }
            },
            "autoscalingProfile": "",
            "enableNodeAutoprovisioning": False,
            "resourceLimits": [
                {
                    "maximum": "",
                    "minimum": "",
                    "resourceType": ""
                }
            ]
        },
        "binaryAuthorization": {
            "enabled": False,
            "evaluationMode": ""
        },
        "clusterIpv4Cidr": "",
        "clusterTelemetry": { "type": "" },
        "conditions": [
            {
                "canonicalCode": "",
                "code": "",
                "message": ""
            }
        ],
        "confidentialNodes": { "enabled": False },
        "costManagementConfig": { "enabled": False },
        "createTime": "",
        "currentMasterVersion": "",
        "currentNodeCount": 0,
        "currentNodeVersion": "",
        "databaseEncryption": {
            "keyName": "",
            "state": ""
        },
        "defaultMaxPodsConstraint": { "maxPodsPerNode": "" },
        "description": "",
        "enableKubernetesAlpha": False,
        "enableTpu": False,
        "endpoint": "",
        "etag": "",
        "expireTime": "",
        "fleet": {
            "membership": "",
            "preRegistered": False,
            "project": ""
        },
        "id": "",
        "identityServiceConfig": { "enabled": False },
        "initialClusterVersion": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "ipAllocationPolicy": {
            "additionalPodRangesConfig": { "podRangeNames": [] },
            "allowRouteOverlap": False,
            "clusterIpv4Cidr": "",
            "clusterIpv4CidrBlock": "",
            "clusterSecondaryRangeName": "",
            "createSubnetwork": False,
            "ipv6AccessType": "",
            "nodeIpv4Cidr": "",
            "nodeIpv4CidrBlock": "",
            "podCidrOverprovisionConfig": { "disable": False },
            "servicesIpv4Cidr": "",
            "servicesIpv4CidrBlock": "",
            "servicesIpv6CidrBlock": "",
            "servicesSecondaryRangeName": "",
            "stackType": "",
            "subnetIpv6CidrBlock": "",
            "subnetworkName": "",
            "tpuIpv4CidrBlock": "",
            "useIpAliases": False,
            "useRoutes": False
        },
        "labelFingerprint": "",
        "legacyAbac": { "enabled": False },
        "location": "",
        "locations": [],
        "loggingConfig": { "componentConfig": { "enableComponents": [] } },
        "loggingService": "",
        "maintenancePolicy": {
            "resourceVersion": "",
            "window": {
                "dailyMaintenanceWindow": {
                    "duration": "",
                    "startTime": ""
                },
                "maintenanceExclusions": {},
                "recurringWindow": {
                    "recurrence": "",
                    "window": {
                        "endTime": "",
                        "maintenanceExclusionOptions": { "scope": "" },
                        "startTime": ""
                    }
                }
            }
        },
        "master": {},
        "masterAuth": {
            "clientCertificate": "",
            "clientCertificateConfig": { "issueClientCertificate": False },
            "clientKey": "",
            "clusterCaCertificate": "",
            "password": "",
            "username": ""
        },
        "masterAuthorizedNetworksConfig": {
            "cidrBlocks": [
                {
                    "cidrBlock": "",
                    "displayName": ""
                }
            ],
            "enabled": False,
            "gcpPublicCidrsAccessEnabled": False
        },
        "masterIpv4CidrBlock": "",
        "meshCertificates": { "enableCertificates": False },
        "monitoringConfig": {
            "componentConfig": { "enableComponents": [] },
            "managedPrometheusConfig": { "enabled": False }
        },
        "monitoringService": "",
        "name": "",
        "network": "",
        "networkConfig": {
            "datapathProvider": "",
            "defaultSnatStatus": { "disabled": False },
            "dnsConfig": {
                "clusterDns": "",
                "clusterDnsDomain": "",
                "clusterDnsScope": ""
            },
            "enableIntraNodeVisibility": False,
            "enableL4ilbSubsetting": False,
            "gatewayApiConfig": { "channel": "" },
            "network": "",
            "privateIpv6GoogleAccess": "",
            "serviceExternalIpsConfig": { "enabled": False },
            "subnetwork": ""
        },
        "networkPolicy": {
            "enabled": False,
            "provider": ""
        },
        "nodeConfig": {
            "accelerators": [
                {
                    "acceleratorCount": "",
                    "acceleratorType": "",
                    "gpuPartitionSize": "",
                    "gpuSharingConfig": {
                        "gpuSharingStrategy": "",
                        "maxSharedClientsPerGpu": ""
                    },
                    "maxTimeSharedClientsPerGpu": ""
                }
            ],
            "advancedMachineFeatures": { "threadsPerCore": "" },
            "bootDiskKmsKey": "",
            "confidentialNodes": {},
            "diskSizeGb": 0,
            "diskType": "",
            "ephemeralStorageConfig": { "localSsdCount": 0 },
            "ephemeralStorageLocalSsdConfig": { "localSsdCount": 0 },
            "fastSocket": { "enabled": False },
            "gcfsConfig": { "enabled": False },
            "gvnic": { "enabled": False },
            "imageType": "",
            "kubeletConfig": {
                "cpuCfsQuota": False,
                "cpuCfsQuotaPeriod": "",
                "cpuManagerPolicy": "",
                "podPidsLimit": ""
            },
            "labels": {},
            "linuxNodeConfig": {
                "cgroupMode": "",
                "sysctls": {}
            },
            "localNvmeSsdBlockConfig": { "localSsdCount": 0 },
            "localSsdCount": 0,
            "loggingConfig": { "variantConfig": { "variant": "" } },
            "machineType": "",
            "metadata": {},
            "minCpuPlatform": "",
            "nodeGroup": "",
            "oauthScopes": [],
            "preemptible": False,
            "reservationAffinity": {
                "consumeReservationType": "",
                "key": "",
                "values": []
            },
            "resourceLabels": {},
            "sandboxConfig": {
                "sandboxType": "",
                "type": ""
            },
            "serviceAccount": "",
            "shieldedInstanceConfig": {},
            "spot": False,
            "tags": [],
            "taints": [
                {
                    "effect": "",
                    "key": "",
                    "value": ""
                }
            ],
            "windowsNodeConfig": { "osVersion": "" },
            "workloadMetadataConfig": {
                "mode": "",
                "nodeMetadata": ""
            }
        },
        "nodeIpv4CidrSize": 0,
        "nodePoolAutoConfig": { "networkTags": { "tags": [] } },
        "nodePoolDefaults": { "nodeConfigDefaults": {
                "gcfsConfig": {},
                "loggingConfig": {}
            } },
        "nodePools": [
            {
                "autoscaling": {
                    "autoprovisioned": False,
                    "enabled": False,
                    "locationPolicy": "",
                    "maxNodeCount": 0,
                    "minNodeCount": 0,
                    "totalMaxNodeCount": 0,
                    "totalMinNodeCount": 0
                },
                "conditions": [{}],
                "config": {},
                "etag": "",
                "initialNodeCount": 0,
                "instanceGroupUrls": [],
                "locations": [],
                "management": {},
                "maxPodsConstraint": {},
                "name": "",
                "networkConfig": {
                    "createPodRange": False,
                    "enablePrivateNodes": False,
                    "networkPerformanceConfig": {
                        "externalIpEgressBandwidthTier": "",
                        "totalEgressBandwidthTier": ""
                    },
                    "podCidrOverprovisionConfig": {},
                    "podIpv4CidrBlock": "",
                    "podRange": ""
                },
                "placementPolicy": { "type": "" },
                "podIpv4CidrSize": 0,
                "selfLink": "",
                "status": "",
                "statusMessage": "",
                "updateInfo": { "blueGreenInfo": {
                        "blueInstanceGroupUrls": [],
                        "bluePoolDeletionStartTime": "",
                        "greenInstanceGroupUrls": [],
                        "greenPoolVersion": "",
                        "phase": ""
                    } },
                "upgradeSettings": {},
                "version": ""
            }
        ],
        "notificationConfig": { "pubsub": {
                "enabled": False,
                "filter": { "eventType": [] },
                "topic": ""
            } },
        "podSecurityPolicyConfig": { "enabled": False },
        "privateCluster": False,
        "privateClusterConfig": {
            "enablePrivateEndpoint": False,
            "enablePrivateNodes": False,
            "masterGlobalAccessConfig": { "enabled": False },
            "masterIpv4CidrBlock": "",
            "peeringName": "",
            "privateEndpoint": "",
            "privateEndpointSubnetwork": "",
            "publicEndpoint": ""
        },
        "protectConfig": {
            "workloadConfig": { "auditMode": "" },
            "workloadVulnerabilityMode": ""
        },
        "releaseChannel": { "channel": "" },
        "resourceLabels": {},
        "resourceUsageExportConfig": {
            "bigqueryDestination": { "datasetId": "" },
            "consumptionMeteringConfig": { "enabled": False },
            "enableNetworkEgressMetering": False
        },
        "selfLink": "",
        "servicesIpv4Cidr": "",
        "shieldedNodes": { "enabled": False },
        "status": "",
        "statusMessage": "",
        "subnetwork": "",
        "tpuConfig": {
            "enabled": False,
            "ipv4CidrBlock": "",
            "useServiceNetworking": False
        },
        "tpuIpv4CidrBlock": "",
        "verticalPodAutoscaling": { "enabled": False },
        "workloadAltsConfig": { "enableAlts": False },
        "workloadCertificates": { "enableCertificates": False },
        "workloadIdentityConfig": {
            "identityNamespace": "",
            "identityProvider": "",
            "workloadPool": ""
        },
        "zone": ""
    },
    "parent": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:parent/clusters"

payload <- "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:parent/clusters")

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  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:parent/clusters') do |req|
  req.body = "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "cluster": json!({
            "addonsConfig": json!({
                "cloudRunConfig": json!({
                    "disabled": false,
                    "loadBalancerType": ""
                }),
                "configConnectorConfig": json!({"enabled": false}),
                "dnsCacheConfig": json!({"enabled": false}),
                "gcePersistentDiskCsiDriverConfig": json!({"enabled": false}),
                "gcpFilestoreCsiDriverConfig": json!({"enabled": false}),
                "gkeBackupAgentConfig": json!({"enabled": false}),
                "horizontalPodAutoscaling": json!({"disabled": false}),
                "httpLoadBalancing": json!({"disabled": false}),
                "istioConfig": json!({
                    "auth": "",
                    "disabled": false
                }),
                "kalmConfig": json!({"enabled": false}),
                "kubernetesDashboard": json!({"disabled": false}),
                "networkPolicyConfig": json!({"disabled": false})
            }),
            "authenticatorGroupsConfig": json!({
                "enabled": false,
                "securityGroup": ""
            }),
            "autopilot": json!({"enabled": false}),
            "autoscaling": json!({
                "autoprovisioningLocations": (),
                "autoprovisioningNodePoolDefaults": json!({
                    "bootDiskKmsKey": "",
                    "diskSizeGb": 0,
                    "diskType": "",
                    "imageType": "",
                    "management": json!({
                        "autoRepair": false,
                        "autoUpgrade": false,
                        "upgradeOptions": json!({
                            "autoUpgradeStartTime": "",
                            "description": ""
                        })
                    }),
                    "minCpuPlatform": "",
                    "oauthScopes": (),
                    "serviceAccount": "",
                    "shieldedInstanceConfig": json!({
                        "enableIntegrityMonitoring": false,
                        "enableSecureBoot": false
                    }),
                    "upgradeSettings": json!({
                        "blueGreenSettings": json!({
                            "nodePoolSoakDuration": "",
                            "standardRolloutPolicy": json!({
                                "batchNodeCount": 0,
                                "batchPercentage": "",
                                "batchSoakDuration": ""
                            })
                        }),
                        "maxSurge": 0,
                        "maxUnavailable": 0,
                        "strategy": ""
                    })
                }),
                "autoscalingProfile": "",
                "enableNodeAutoprovisioning": false,
                "resourceLimits": (
                    json!({
                        "maximum": "",
                        "minimum": "",
                        "resourceType": ""
                    })
                )
            }),
            "binaryAuthorization": json!({
                "enabled": false,
                "evaluationMode": ""
            }),
            "clusterIpv4Cidr": "",
            "clusterTelemetry": json!({"type": ""}),
            "conditions": (
                json!({
                    "canonicalCode": "",
                    "code": "",
                    "message": ""
                })
            ),
            "confidentialNodes": json!({"enabled": false}),
            "costManagementConfig": json!({"enabled": false}),
            "createTime": "",
            "currentMasterVersion": "",
            "currentNodeCount": 0,
            "currentNodeVersion": "",
            "databaseEncryption": json!({
                "keyName": "",
                "state": ""
            }),
            "defaultMaxPodsConstraint": json!({"maxPodsPerNode": ""}),
            "description": "",
            "enableKubernetesAlpha": false,
            "enableTpu": false,
            "endpoint": "",
            "etag": "",
            "expireTime": "",
            "fleet": json!({
                "membership": "",
                "preRegistered": false,
                "project": ""
            }),
            "id": "",
            "identityServiceConfig": json!({"enabled": false}),
            "initialClusterVersion": "",
            "initialNodeCount": 0,
            "instanceGroupUrls": (),
            "ipAllocationPolicy": json!({
                "additionalPodRangesConfig": json!({"podRangeNames": ()}),
                "allowRouteOverlap": false,
                "clusterIpv4Cidr": "",
                "clusterIpv4CidrBlock": "",
                "clusterSecondaryRangeName": "",
                "createSubnetwork": false,
                "ipv6AccessType": "",
                "nodeIpv4Cidr": "",
                "nodeIpv4CidrBlock": "",
                "podCidrOverprovisionConfig": json!({"disable": false}),
                "servicesIpv4Cidr": "",
                "servicesIpv4CidrBlock": "",
                "servicesIpv6CidrBlock": "",
                "servicesSecondaryRangeName": "",
                "stackType": "",
                "subnetIpv6CidrBlock": "",
                "subnetworkName": "",
                "tpuIpv4CidrBlock": "",
                "useIpAliases": false,
                "useRoutes": false
            }),
            "labelFingerprint": "",
            "legacyAbac": json!({"enabled": false}),
            "location": "",
            "locations": (),
            "loggingConfig": json!({"componentConfig": json!({"enableComponents": ()})}),
            "loggingService": "",
            "maintenancePolicy": json!({
                "resourceVersion": "",
                "window": json!({
                    "dailyMaintenanceWindow": json!({
                        "duration": "",
                        "startTime": ""
                    }),
                    "maintenanceExclusions": json!({}),
                    "recurringWindow": json!({
                        "recurrence": "",
                        "window": json!({
                            "endTime": "",
                            "maintenanceExclusionOptions": json!({"scope": ""}),
                            "startTime": ""
                        })
                    })
                })
            }),
            "master": json!({}),
            "masterAuth": json!({
                "clientCertificate": "",
                "clientCertificateConfig": json!({"issueClientCertificate": false}),
                "clientKey": "",
                "clusterCaCertificate": "",
                "password": "",
                "username": ""
            }),
            "masterAuthorizedNetworksConfig": json!({
                "cidrBlocks": (
                    json!({
                        "cidrBlock": "",
                        "displayName": ""
                    })
                ),
                "enabled": false,
                "gcpPublicCidrsAccessEnabled": false
            }),
            "masterIpv4CidrBlock": "",
            "meshCertificates": json!({"enableCertificates": false}),
            "monitoringConfig": json!({
                "componentConfig": json!({"enableComponents": ()}),
                "managedPrometheusConfig": json!({"enabled": false})
            }),
            "monitoringService": "",
            "name": "",
            "network": "",
            "networkConfig": json!({
                "datapathProvider": "",
                "defaultSnatStatus": json!({"disabled": false}),
                "dnsConfig": json!({
                    "clusterDns": "",
                    "clusterDnsDomain": "",
                    "clusterDnsScope": ""
                }),
                "enableIntraNodeVisibility": false,
                "enableL4ilbSubsetting": false,
                "gatewayApiConfig": json!({"channel": ""}),
                "network": "",
                "privateIpv6GoogleAccess": "",
                "serviceExternalIpsConfig": json!({"enabled": false}),
                "subnetwork": ""
            }),
            "networkPolicy": json!({
                "enabled": false,
                "provider": ""
            }),
            "nodeConfig": json!({
                "accelerators": (
                    json!({
                        "acceleratorCount": "",
                        "acceleratorType": "",
                        "gpuPartitionSize": "",
                        "gpuSharingConfig": json!({
                            "gpuSharingStrategy": "",
                            "maxSharedClientsPerGpu": ""
                        }),
                        "maxTimeSharedClientsPerGpu": ""
                    })
                ),
                "advancedMachineFeatures": json!({"threadsPerCore": ""}),
                "bootDiskKmsKey": "",
                "confidentialNodes": json!({}),
                "diskSizeGb": 0,
                "diskType": "",
                "ephemeralStorageConfig": json!({"localSsdCount": 0}),
                "ephemeralStorageLocalSsdConfig": json!({"localSsdCount": 0}),
                "fastSocket": json!({"enabled": false}),
                "gcfsConfig": json!({"enabled": false}),
                "gvnic": json!({"enabled": false}),
                "imageType": "",
                "kubeletConfig": json!({
                    "cpuCfsQuota": false,
                    "cpuCfsQuotaPeriod": "",
                    "cpuManagerPolicy": "",
                    "podPidsLimit": ""
                }),
                "labels": json!({}),
                "linuxNodeConfig": json!({
                    "cgroupMode": "",
                    "sysctls": json!({})
                }),
                "localNvmeSsdBlockConfig": json!({"localSsdCount": 0}),
                "localSsdCount": 0,
                "loggingConfig": json!({"variantConfig": json!({"variant": ""})}),
                "machineType": "",
                "metadata": json!({}),
                "minCpuPlatform": "",
                "nodeGroup": "",
                "oauthScopes": (),
                "preemptible": false,
                "reservationAffinity": json!({
                    "consumeReservationType": "",
                    "key": "",
                    "values": ()
                }),
                "resourceLabels": json!({}),
                "sandboxConfig": json!({
                    "sandboxType": "",
                    "type": ""
                }),
                "serviceAccount": "",
                "shieldedInstanceConfig": json!({}),
                "spot": false,
                "tags": (),
                "taints": (
                    json!({
                        "effect": "",
                        "key": "",
                        "value": ""
                    })
                ),
                "windowsNodeConfig": json!({"osVersion": ""}),
                "workloadMetadataConfig": json!({
                    "mode": "",
                    "nodeMetadata": ""
                })
            }),
            "nodeIpv4CidrSize": 0,
            "nodePoolAutoConfig": json!({"networkTags": json!({"tags": ()})}),
            "nodePoolDefaults": json!({"nodeConfigDefaults": json!({
                    "gcfsConfig": json!({}),
                    "loggingConfig": json!({})
                })}),
            "nodePools": (
                json!({
                    "autoscaling": json!({
                        "autoprovisioned": false,
                        "enabled": false,
                        "locationPolicy": "",
                        "maxNodeCount": 0,
                        "minNodeCount": 0,
                        "totalMaxNodeCount": 0,
                        "totalMinNodeCount": 0
                    }),
                    "conditions": (json!({})),
                    "config": json!({}),
                    "etag": "",
                    "initialNodeCount": 0,
                    "instanceGroupUrls": (),
                    "locations": (),
                    "management": json!({}),
                    "maxPodsConstraint": json!({}),
                    "name": "",
                    "networkConfig": json!({
                        "createPodRange": false,
                        "enablePrivateNodes": false,
                        "networkPerformanceConfig": json!({
                            "externalIpEgressBandwidthTier": "",
                            "totalEgressBandwidthTier": ""
                        }),
                        "podCidrOverprovisionConfig": json!({}),
                        "podIpv4CidrBlock": "",
                        "podRange": ""
                    }),
                    "placementPolicy": json!({"type": ""}),
                    "podIpv4CidrSize": 0,
                    "selfLink": "",
                    "status": "",
                    "statusMessage": "",
                    "updateInfo": json!({"blueGreenInfo": json!({
                            "blueInstanceGroupUrls": (),
                            "bluePoolDeletionStartTime": "",
                            "greenInstanceGroupUrls": (),
                            "greenPoolVersion": "",
                            "phase": ""
                        })}),
                    "upgradeSettings": json!({}),
                    "version": ""
                })
            ),
            "notificationConfig": json!({"pubsub": json!({
                    "enabled": false,
                    "filter": json!({"eventType": ()}),
                    "topic": ""
                })}),
            "podSecurityPolicyConfig": json!({"enabled": false}),
            "privateCluster": false,
            "privateClusterConfig": json!({
                "enablePrivateEndpoint": false,
                "enablePrivateNodes": false,
                "masterGlobalAccessConfig": json!({"enabled": false}),
                "masterIpv4CidrBlock": "",
                "peeringName": "",
                "privateEndpoint": "",
                "privateEndpointSubnetwork": "",
                "publicEndpoint": ""
            }),
            "protectConfig": json!({
                "workloadConfig": json!({"auditMode": ""}),
                "workloadVulnerabilityMode": ""
            }),
            "releaseChannel": json!({"channel": ""}),
            "resourceLabels": json!({}),
            "resourceUsageExportConfig": json!({
                "bigqueryDestination": json!({"datasetId": ""}),
                "consumptionMeteringConfig": json!({"enabled": false}),
                "enableNetworkEgressMetering": false
            }),
            "selfLink": "",
            "servicesIpv4Cidr": "",
            "shieldedNodes": json!({"enabled": false}),
            "status": "",
            "statusMessage": "",
            "subnetwork": "",
            "tpuConfig": json!({
                "enabled": false,
                "ipv4CidrBlock": "",
                "useServiceNetworking": false
            }),
            "tpuIpv4CidrBlock": "",
            "verticalPodAutoscaling": json!({"enabled": false}),
            "workloadAltsConfig": json!({"enableAlts": false}),
            "workloadCertificates": json!({"enableCertificates": false}),
            "workloadIdentityConfig": json!({
                "identityNamespace": "",
                "identityProvider": "",
                "workloadPool": ""
            }),
            "zone": ""
        }),
        "parent": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:parent/clusters \
  --header 'content-type: application/json' \
  --data '{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:parent/clusters \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "cluster": {\n    "addonsConfig": {\n      "cloudRunConfig": {\n        "disabled": false,\n        "loadBalancerType": ""\n      },\n      "configConnectorConfig": {\n        "enabled": false\n      },\n      "dnsCacheConfig": {\n        "enabled": false\n      },\n      "gcePersistentDiskCsiDriverConfig": {\n        "enabled": false\n      },\n      "gcpFilestoreCsiDriverConfig": {\n        "enabled": false\n      },\n      "gkeBackupAgentConfig": {\n        "enabled": false\n      },\n      "horizontalPodAutoscaling": {\n        "disabled": false\n      },\n      "httpLoadBalancing": {\n        "disabled": false\n      },\n      "istioConfig": {\n        "auth": "",\n        "disabled": false\n      },\n      "kalmConfig": {\n        "enabled": false\n      },\n      "kubernetesDashboard": {\n        "disabled": false\n      },\n      "networkPolicyConfig": {\n        "disabled": false\n      }\n    },\n    "authenticatorGroupsConfig": {\n      "enabled": false,\n      "securityGroup": ""\n    },\n    "autopilot": {\n      "enabled": false\n    },\n    "autoscaling": {\n      "autoprovisioningLocations": [],\n      "autoprovisioningNodePoolDefaults": {\n        "bootDiskKmsKey": "",\n        "diskSizeGb": 0,\n        "diskType": "",\n        "imageType": "",\n        "management": {\n          "autoRepair": false,\n          "autoUpgrade": false,\n          "upgradeOptions": {\n            "autoUpgradeStartTime": "",\n            "description": ""\n          }\n        },\n        "minCpuPlatform": "",\n        "oauthScopes": [],\n        "serviceAccount": "",\n        "shieldedInstanceConfig": {\n          "enableIntegrityMonitoring": false,\n          "enableSecureBoot": false\n        },\n        "upgradeSettings": {\n          "blueGreenSettings": {\n            "nodePoolSoakDuration": "",\n            "standardRolloutPolicy": {\n              "batchNodeCount": 0,\n              "batchPercentage": "",\n              "batchSoakDuration": ""\n            }\n          },\n          "maxSurge": 0,\n          "maxUnavailable": 0,\n          "strategy": ""\n        }\n      },\n      "autoscalingProfile": "",\n      "enableNodeAutoprovisioning": false,\n      "resourceLimits": [\n        {\n          "maximum": "",\n          "minimum": "",\n          "resourceType": ""\n        }\n      ]\n    },\n    "binaryAuthorization": {\n      "enabled": false,\n      "evaluationMode": ""\n    },\n    "clusterIpv4Cidr": "",\n    "clusterTelemetry": {\n      "type": ""\n    },\n    "conditions": [\n      {\n        "canonicalCode": "",\n        "code": "",\n        "message": ""\n      }\n    ],\n    "confidentialNodes": {\n      "enabled": false\n    },\n    "costManagementConfig": {\n      "enabled": false\n    },\n    "createTime": "",\n    "currentMasterVersion": "",\n    "currentNodeCount": 0,\n    "currentNodeVersion": "",\n    "databaseEncryption": {\n      "keyName": "",\n      "state": ""\n    },\n    "defaultMaxPodsConstraint": {\n      "maxPodsPerNode": ""\n    },\n    "description": "",\n    "enableKubernetesAlpha": false,\n    "enableTpu": false,\n    "endpoint": "",\n    "etag": "",\n    "expireTime": "",\n    "fleet": {\n      "membership": "",\n      "preRegistered": false,\n      "project": ""\n    },\n    "id": "",\n    "identityServiceConfig": {\n      "enabled": false\n    },\n    "initialClusterVersion": "",\n    "initialNodeCount": 0,\n    "instanceGroupUrls": [],\n    "ipAllocationPolicy": {\n      "additionalPodRangesConfig": {\n        "podRangeNames": []\n      },\n      "allowRouteOverlap": false,\n      "clusterIpv4Cidr": "",\n      "clusterIpv4CidrBlock": "",\n      "clusterSecondaryRangeName": "",\n      "createSubnetwork": false,\n      "ipv6AccessType": "",\n      "nodeIpv4Cidr": "",\n      "nodeIpv4CidrBlock": "",\n      "podCidrOverprovisionConfig": {\n        "disable": false\n      },\n      "servicesIpv4Cidr": "",\n      "servicesIpv4CidrBlock": "",\n      "servicesIpv6CidrBlock": "",\n      "servicesSecondaryRangeName": "",\n      "stackType": "",\n      "subnetIpv6CidrBlock": "",\n      "subnetworkName": "",\n      "tpuIpv4CidrBlock": "",\n      "useIpAliases": false,\n      "useRoutes": false\n    },\n    "labelFingerprint": "",\n    "legacyAbac": {\n      "enabled": false\n    },\n    "location": "",\n    "locations": [],\n    "loggingConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      }\n    },\n    "loggingService": "",\n    "maintenancePolicy": {\n      "resourceVersion": "",\n      "window": {\n        "dailyMaintenanceWindow": {\n          "duration": "",\n          "startTime": ""\n        },\n        "maintenanceExclusions": {},\n        "recurringWindow": {\n          "recurrence": "",\n          "window": {\n            "endTime": "",\n            "maintenanceExclusionOptions": {\n              "scope": ""\n            },\n            "startTime": ""\n          }\n        }\n      }\n    },\n    "master": {},\n    "masterAuth": {\n      "clientCertificate": "",\n      "clientCertificateConfig": {\n        "issueClientCertificate": false\n      },\n      "clientKey": "",\n      "clusterCaCertificate": "",\n      "password": "",\n      "username": ""\n    },\n    "masterAuthorizedNetworksConfig": {\n      "cidrBlocks": [\n        {\n          "cidrBlock": "",\n          "displayName": ""\n        }\n      ],\n      "enabled": false,\n      "gcpPublicCidrsAccessEnabled": false\n    },\n    "masterIpv4CidrBlock": "",\n    "meshCertificates": {\n      "enableCertificates": false\n    },\n    "monitoringConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      },\n      "managedPrometheusConfig": {\n        "enabled": false\n      }\n    },\n    "monitoringService": "",\n    "name": "",\n    "network": "",\n    "networkConfig": {\n      "datapathProvider": "",\n      "defaultSnatStatus": {\n        "disabled": false\n      },\n      "dnsConfig": {\n        "clusterDns": "",\n        "clusterDnsDomain": "",\n        "clusterDnsScope": ""\n      },\n      "enableIntraNodeVisibility": false,\n      "enableL4ilbSubsetting": false,\n      "gatewayApiConfig": {\n        "channel": ""\n      },\n      "network": "",\n      "privateIpv6GoogleAccess": "",\n      "serviceExternalIpsConfig": {\n        "enabled": false\n      },\n      "subnetwork": ""\n    },\n    "networkPolicy": {\n      "enabled": false,\n      "provider": ""\n    },\n    "nodeConfig": {\n      "accelerators": [\n        {\n          "acceleratorCount": "",\n          "acceleratorType": "",\n          "gpuPartitionSize": "",\n          "gpuSharingConfig": {\n            "gpuSharingStrategy": "",\n            "maxSharedClientsPerGpu": ""\n          },\n          "maxTimeSharedClientsPerGpu": ""\n        }\n      ],\n      "advancedMachineFeatures": {\n        "threadsPerCore": ""\n      },\n      "bootDiskKmsKey": "",\n      "confidentialNodes": {},\n      "diskSizeGb": 0,\n      "diskType": "",\n      "ephemeralStorageConfig": {\n        "localSsdCount": 0\n      },\n      "ephemeralStorageLocalSsdConfig": {\n        "localSsdCount": 0\n      },\n      "fastSocket": {\n        "enabled": false\n      },\n      "gcfsConfig": {\n        "enabled": false\n      },\n      "gvnic": {\n        "enabled": false\n      },\n      "imageType": "",\n      "kubeletConfig": {\n        "cpuCfsQuota": false,\n        "cpuCfsQuotaPeriod": "",\n        "cpuManagerPolicy": "",\n        "podPidsLimit": ""\n      },\n      "labels": {},\n      "linuxNodeConfig": {\n        "cgroupMode": "",\n        "sysctls": {}\n      },\n      "localNvmeSsdBlockConfig": {\n        "localSsdCount": 0\n      },\n      "localSsdCount": 0,\n      "loggingConfig": {\n        "variantConfig": {\n          "variant": ""\n        }\n      },\n      "machineType": "",\n      "metadata": {},\n      "minCpuPlatform": "",\n      "nodeGroup": "",\n      "oauthScopes": [],\n      "preemptible": false,\n      "reservationAffinity": {\n        "consumeReservationType": "",\n        "key": "",\n        "values": []\n      },\n      "resourceLabels": {},\n      "sandboxConfig": {\n        "sandboxType": "",\n        "type": ""\n      },\n      "serviceAccount": "",\n      "shieldedInstanceConfig": {},\n      "spot": false,\n      "tags": [],\n      "taints": [\n        {\n          "effect": "",\n          "key": "",\n          "value": ""\n        }\n      ],\n      "windowsNodeConfig": {\n        "osVersion": ""\n      },\n      "workloadMetadataConfig": {\n        "mode": "",\n        "nodeMetadata": ""\n      }\n    },\n    "nodeIpv4CidrSize": 0,\n    "nodePoolAutoConfig": {\n      "networkTags": {\n        "tags": []\n      }\n    },\n    "nodePoolDefaults": {\n      "nodeConfigDefaults": {\n        "gcfsConfig": {},\n        "loggingConfig": {}\n      }\n    },\n    "nodePools": [\n      {\n        "autoscaling": {\n          "autoprovisioned": false,\n          "enabled": false,\n          "locationPolicy": "",\n          "maxNodeCount": 0,\n          "minNodeCount": 0,\n          "totalMaxNodeCount": 0,\n          "totalMinNodeCount": 0\n        },\n        "conditions": [\n          {}\n        ],\n        "config": {},\n        "etag": "",\n        "initialNodeCount": 0,\n        "instanceGroupUrls": [],\n        "locations": [],\n        "management": {},\n        "maxPodsConstraint": {},\n        "name": "",\n        "networkConfig": {\n          "createPodRange": false,\n          "enablePrivateNodes": false,\n          "networkPerformanceConfig": {\n            "externalIpEgressBandwidthTier": "",\n            "totalEgressBandwidthTier": ""\n          },\n          "podCidrOverprovisionConfig": {},\n          "podIpv4CidrBlock": "",\n          "podRange": ""\n        },\n        "placementPolicy": {\n          "type": ""\n        },\n        "podIpv4CidrSize": 0,\n        "selfLink": "",\n        "status": "",\n        "statusMessage": "",\n        "updateInfo": {\n          "blueGreenInfo": {\n            "blueInstanceGroupUrls": [],\n            "bluePoolDeletionStartTime": "",\n            "greenInstanceGroupUrls": [],\n            "greenPoolVersion": "",\n            "phase": ""\n          }\n        },\n        "upgradeSettings": {},\n        "version": ""\n      }\n    ],\n    "notificationConfig": {\n      "pubsub": {\n        "enabled": false,\n        "filter": {\n          "eventType": []\n        },\n        "topic": ""\n      }\n    },\n    "podSecurityPolicyConfig": {\n      "enabled": false\n    },\n    "privateCluster": false,\n    "privateClusterConfig": {\n      "enablePrivateEndpoint": false,\n      "enablePrivateNodes": false,\n      "masterGlobalAccessConfig": {\n        "enabled": false\n      },\n      "masterIpv4CidrBlock": "",\n      "peeringName": "",\n      "privateEndpoint": "",\n      "privateEndpointSubnetwork": "",\n      "publicEndpoint": ""\n    },\n    "protectConfig": {\n      "workloadConfig": {\n        "auditMode": ""\n      },\n      "workloadVulnerabilityMode": ""\n    },\n    "releaseChannel": {\n      "channel": ""\n    },\n    "resourceLabels": {},\n    "resourceUsageExportConfig": {\n      "bigqueryDestination": {\n        "datasetId": ""\n      },\n      "consumptionMeteringConfig": {\n        "enabled": false\n      },\n      "enableNetworkEgressMetering": false\n    },\n    "selfLink": "",\n    "servicesIpv4Cidr": "",\n    "shieldedNodes": {\n      "enabled": false\n    },\n    "status": "",\n    "statusMessage": "",\n    "subnetwork": "",\n    "tpuConfig": {\n      "enabled": false,\n      "ipv4CidrBlock": "",\n      "useServiceNetworking": false\n    },\n    "tpuIpv4CidrBlock": "",\n    "verticalPodAutoscaling": {\n      "enabled": false\n    },\n    "workloadAltsConfig": {\n      "enableAlts": false\n    },\n    "workloadCertificates": {\n      "enableCertificates": false\n    },\n    "workloadIdentityConfig": {\n      "identityNamespace": "",\n      "identityProvider": "",\n      "workloadPool": ""\n    },\n    "zone": ""\n  },\n  "parent": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/clusters
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "cluster": [
    "addonsConfig": [
      "cloudRunConfig": [
        "disabled": false,
        "loadBalancerType": ""
      ],
      "configConnectorConfig": ["enabled": false],
      "dnsCacheConfig": ["enabled": false],
      "gcePersistentDiskCsiDriverConfig": ["enabled": false],
      "gcpFilestoreCsiDriverConfig": ["enabled": false],
      "gkeBackupAgentConfig": ["enabled": false],
      "horizontalPodAutoscaling": ["disabled": false],
      "httpLoadBalancing": ["disabled": false],
      "istioConfig": [
        "auth": "",
        "disabled": false
      ],
      "kalmConfig": ["enabled": false],
      "kubernetesDashboard": ["disabled": false],
      "networkPolicyConfig": ["disabled": false]
    ],
    "authenticatorGroupsConfig": [
      "enabled": false,
      "securityGroup": ""
    ],
    "autopilot": ["enabled": false],
    "autoscaling": [
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": [
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": [
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": [
            "autoUpgradeStartTime": "",
            "description": ""
          ]
        ],
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": [
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        ],
        "upgradeSettings": [
          "blueGreenSettings": [
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": [
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            ]
          ],
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        ]
      ],
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        [
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        ]
      ]
    ],
    "binaryAuthorization": [
      "enabled": false,
      "evaluationMode": ""
    ],
    "clusterIpv4Cidr": "",
    "clusterTelemetry": ["type": ""],
    "conditions": [
      [
        "canonicalCode": "",
        "code": "",
        "message": ""
      ]
    ],
    "confidentialNodes": ["enabled": false],
    "costManagementConfig": ["enabled": false],
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": [
      "keyName": "",
      "state": ""
    ],
    "defaultMaxPodsConstraint": ["maxPodsPerNode": ""],
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": [
      "membership": "",
      "preRegistered": false,
      "project": ""
    ],
    "id": "",
    "identityServiceConfig": ["enabled": false],
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": [
      "additionalPodRangesConfig": ["podRangeNames": []],
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": ["disable": false],
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    ],
    "labelFingerprint": "",
    "legacyAbac": ["enabled": false],
    "location": "",
    "locations": [],
    "loggingConfig": ["componentConfig": ["enableComponents": []]],
    "loggingService": "",
    "maintenancePolicy": [
      "resourceVersion": "",
      "window": [
        "dailyMaintenanceWindow": [
          "duration": "",
          "startTime": ""
        ],
        "maintenanceExclusions": [],
        "recurringWindow": [
          "recurrence": "",
          "window": [
            "endTime": "",
            "maintenanceExclusionOptions": ["scope": ""],
            "startTime": ""
          ]
        ]
      ]
    ],
    "master": [],
    "masterAuth": [
      "clientCertificate": "",
      "clientCertificateConfig": ["issueClientCertificate": false],
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    ],
    "masterAuthorizedNetworksConfig": [
      "cidrBlocks": [
        [
          "cidrBlock": "",
          "displayName": ""
        ]
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    ],
    "masterIpv4CidrBlock": "",
    "meshCertificates": ["enableCertificates": false],
    "monitoringConfig": [
      "componentConfig": ["enableComponents": []],
      "managedPrometheusConfig": ["enabled": false]
    ],
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": [
      "datapathProvider": "",
      "defaultSnatStatus": ["disabled": false],
      "dnsConfig": [
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      ],
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": ["channel": ""],
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": ["enabled": false],
      "subnetwork": ""
    ],
    "networkPolicy": [
      "enabled": false,
      "provider": ""
    ],
    "nodeConfig": [
      "accelerators": [
        [
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": [
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          ],
          "maxTimeSharedClientsPerGpu": ""
        ]
      ],
      "advancedMachineFeatures": ["threadsPerCore": ""],
      "bootDiskKmsKey": "",
      "confidentialNodes": [],
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": ["localSsdCount": 0],
      "ephemeralStorageLocalSsdConfig": ["localSsdCount": 0],
      "fastSocket": ["enabled": false],
      "gcfsConfig": ["enabled": false],
      "gvnic": ["enabled": false],
      "imageType": "",
      "kubeletConfig": [
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      ],
      "labels": [],
      "linuxNodeConfig": [
        "cgroupMode": "",
        "sysctls": []
      ],
      "localNvmeSsdBlockConfig": ["localSsdCount": 0],
      "localSsdCount": 0,
      "loggingConfig": ["variantConfig": ["variant": ""]],
      "machineType": "",
      "metadata": [],
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": [
        "consumeReservationType": "",
        "key": "",
        "values": []
      ],
      "resourceLabels": [],
      "sandboxConfig": [
        "sandboxType": "",
        "type": ""
      ],
      "serviceAccount": "",
      "shieldedInstanceConfig": [],
      "spot": false,
      "tags": [],
      "taints": [
        [
          "effect": "",
          "key": "",
          "value": ""
        ]
      ],
      "windowsNodeConfig": ["osVersion": ""],
      "workloadMetadataConfig": [
        "mode": "",
        "nodeMetadata": ""
      ]
    ],
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": ["networkTags": ["tags": []]],
    "nodePoolDefaults": ["nodeConfigDefaults": [
        "gcfsConfig": [],
        "loggingConfig": []
      ]],
    "nodePools": [
      [
        "autoscaling": [
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        ],
        "conditions": [[]],
        "config": [],
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": [],
        "maxPodsConstraint": [],
        "name": "",
        "networkConfig": [
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": [
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          ],
          "podCidrOverprovisionConfig": [],
          "podIpv4CidrBlock": "",
          "podRange": ""
        ],
        "placementPolicy": ["type": ""],
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": ["blueGreenInfo": [
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          ]],
        "upgradeSettings": [],
        "version": ""
      ]
    ],
    "notificationConfig": ["pubsub": [
        "enabled": false,
        "filter": ["eventType": []],
        "topic": ""
      ]],
    "podSecurityPolicyConfig": ["enabled": false],
    "privateCluster": false,
    "privateClusterConfig": [
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": ["enabled": false],
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    ],
    "protectConfig": [
      "workloadConfig": ["auditMode": ""],
      "workloadVulnerabilityMode": ""
    ],
    "releaseChannel": ["channel": ""],
    "resourceLabels": [],
    "resourceUsageExportConfig": [
      "bigqueryDestination": ["datasetId": ""],
      "consumptionMeteringConfig": ["enabled": false],
      "enableNetworkEgressMetering": false
    ],
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": ["enabled": false],
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": [
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    ],
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": ["enabled": false],
    "workloadAltsConfig": ["enableAlts": false],
    "workloadCertificates": ["enableCertificates": false],
    "workloadIdentityConfig": [
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    ],
    "zone": ""
  ],
  "parent": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/clusters")! 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 container.projects.locations.clusters.getJwks
{{baseUrl}}/v1beta1/:parent/jwks
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/v1beta1/:parent/jwks")
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/jwks"

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

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

func main() {

	url := "{{baseUrl}}/v1beta1/:parent/jwks"

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/jwks'};

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

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

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

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

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

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

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

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

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}}/v1beta1/:parent/jwks'};

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/v1beta1/:parent/jwks")

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

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

url = "{{baseUrl}}/v1beta1/:parent/jwks"

response = requests.get(url)

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

url <- "{{baseUrl}}/v1beta1/:parent/jwks"

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

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

url = URI("{{baseUrl}}/v1beta1/:parent/jwks")

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

puts response.status
puts response.body
use reqwest;

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/jwks")! 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 container.projects.locations.clusters.list
{{baseUrl}}/v1beta1/:parent/clusters
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/v1beta1/:parent/clusters")
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/clusters"

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

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

func main() {

	url := "{{baseUrl}}/v1beta1/:parent/clusters"

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/clusters'};

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

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

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

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

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

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

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

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

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}}/v1beta1/:parent/clusters'};

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/v1beta1/:parent/clusters")

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

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

url = "{{baseUrl}}/v1beta1/:parent/clusters"

response = requests.get(url)

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

url <- "{{baseUrl}}/v1beta1/:parent/clusters"

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

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

url = URI("{{baseUrl}}/v1beta1/:parent/clusters")

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

puts response.status
puts response.body
use reqwest;

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/clusters")! 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 container.projects.locations.clusters.nodePools.completeUpgrade
{{baseUrl}}/v1beta1/:name:completeUpgrade
QUERY PARAMS

name
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

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

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

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:completeUpgrade"

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:completeUpgrade")
  .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/v1beta1/:name:completeUpgrade',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

curl_close($curl);

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

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

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

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

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

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

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

payload = "{}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:completeUpgrade", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:completeUpgrade"

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

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

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

url <- "{{baseUrl}}/v1beta1/:name:completeUpgrade"

payload <- "{}"

encode <- "json"

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

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

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

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

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

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

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

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

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

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

    let payload = json!({});

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

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

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:completeUpgrade")! 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 container.projects.locations.clusters.nodePools.create
{{baseUrl}}/v1beta1/:parent/nodePools
QUERY PARAMS

parent
BODY json

{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:parent/nodePools" {:content-type :json
                                                                      :form-params {:clusterId ""
                                                                                    :nodePool {:autoscaling {:autoprovisioned false
                                                                                                             :enabled false
                                                                                                             :locationPolicy ""
                                                                                                             :maxNodeCount 0
                                                                                                             :minNodeCount 0
                                                                                                             :totalMaxNodeCount 0
                                                                                                             :totalMinNodeCount 0}
                                                                                               :conditions [{:canonicalCode ""
                                                                                                             :code ""
                                                                                                             :message ""}]
                                                                                               :config {:accelerators [{:acceleratorCount ""
                                                                                                                        :acceleratorType ""
                                                                                                                        :gpuPartitionSize ""
                                                                                                                        :gpuSharingConfig {:gpuSharingStrategy ""
                                                                                                                                           :maxSharedClientsPerGpu ""}
                                                                                                                        :maxTimeSharedClientsPerGpu ""}]
                                                                                                        :advancedMachineFeatures {:threadsPerCore ""}
                                                                                                        :bootDiskKmsKey ""
                                                                                                        :confidentialNodes {:enabled false}
                                                                                                        :diskSizeGb 0
                                                                                                        :diskType ""
                                                                                                        :ephemeralStorageConfig {:localSsdCount 0}
                                                                                                        :ephemeralStorageLocalSsdConfig {:localSsdCount 0}
                                                                                                        :fastSocket {:enabled false}
                                                                                                        :gcfsConfig {:enabled false}
                                                                                                        :gvnic {:enabled false}
                                                                                                        :imageType ""
                                                                                                        :kubeletConfig {:cpuCfsQuota false
                                                                                                                        :cpuCfsQuotaPeriod ""
                                                                                                                        :cpuManagerPolicy ""
                                                                                                                        :podPidsLimit ""}
                                                                                                        :labels {}
                                                                                                        :linuxNodeConfig {:cgroupMode ""
                                                                                                                          :sysctls {}}
                                                                                                        :localNvmeSsdBlockConfig {:localSsdCount 0}
                                                                                                        :localSsdCount 0
                                                                                                        :loggingConfig {:variantConfig {:variant ""}}
                                                                                                        :machineType ""
                                                                                                        :metadata {}
                                                                                                        :minCpuPlatform ""
                                                                                                        :nodeGroup ""
                                                                                                        :oauthScopes []
                                                                                                        :preemptible false
                                                                                                        :reservationAffinity {:consumeReservationType ""
                                                                                                                              :key ""
                                                                                                                              :values []}
                                                                                                        :resourceLabels {}
                                                                                                        :sandboxConfig {:sandboxType ""
                                                                                                                        :type ""}
                                                                                                        :serviceAccount ""
                                                                                                        :shieldedInstanceConfig {:enableIntegrityMonitoring false
                                                                                                                                 :enableSecureBoot false}
                                                                                                        :spot false
                                                                                                        :tags []
                                                                                                        :taints [{:effect ""
                                                                                                                  :key ""
                                                                                                                  :value ""}]
                                                                                                        :windowsNodeConfig {:osVersion ""}
                                                                                                        :workloadMetadataConfig {:mode ""
                                                                                                                                 :nodeMetadata ""}}
                                                                                               :etag ""
                                                                                               :initialNodeCount 0
                                                                                               :instanceGroupUrls []
                                                                                               :locations []
                                                                                               :management {:autoRepair false
                                                                                                            :autoUpgrade false
                                                                                                            :upgradeOptions {:autoUpgradeStartTime ""
                                                                                                                             :description ""}}
                                                                                               :maxPodsConstraint {:maxPodsPerNode ""}
                                                                                               :name ""
                                                                                               :networkConfig {:createPodRange false
                                                                                                               :enablePrivateNodes false
                                                                                                               :networkPerformanceConfig {:externalIpEgressBandwidthTier ""
                                                                                                                                          :totalEgressBandwidthTier ""}
                                                                                                               :podCidrOverprovisionConfig {:disable false}
                                                                                                               :podIpv4CidrBlock ""
                                                                                                               :podRange ""}
                                                                                               :placementPolicy {:type ""}
                                                                                               :podIpv4CidrSize 0
                                                                                               :selfLink ""
                                                                                               :status ""
                                                                                               :statusMessage ""
                                                                                               :updateInfo {:blueGreenInfo {:blueInstanceGroupUrls []
                                                                                                                            :bluePoolDeletionStartTime ""
                                                                                                                            :greenInstanceGroupUrls []
                                                                                                                            :greenPoolVersion ""
                                                                                                                            :phase ""}}
                                                                                               :upgradeSettings {:blueGreenSettings {:nodePoolSoakDuration ""
                                                                                                                                     :standardRolloutPolicy {:batchNodeCount 0
                                                                                                                                                             :batchPercentage ""
                                                                                                                                                             :batchSoakDuration ""}}
                                                                                                                 :maxSurge 0
                                                                                                                 :maxUnavailable 0
                                                                                                                 :strategy ""}
                                                                                               :version ""}
                                                                                    :parent ""
                                                                                    :projectId ""
                                                                                    :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/nodePools"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:parent/nodePools"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:parent/nodePools");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:parent/nodePools"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:parent/nodePools HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 3993

{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:parent/nodePools")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:parent/nodePools"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/nodePools")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:parent/nodePools")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  nodePool: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    conditions: [
      {
        canonicalCode: '',
        code: '',
        message: ''
      }
    ],
    config: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {
            gpuSharingStrategy: '',
            maxSharedClientsPerGpu: ''
          },
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {
        threadsPerCore: ''
      },
      bootDiskKmsKey: '',
      confidentialNodes: {
        enabled: false
      },
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {
        localSsdCount: 0
      },
      ephemeralStorageLocalSsdConfig: {
        localSsdCount: 0
      },
      fastSocket: {
        enabled: false
      },
      gcfsConfig: {
        enabled: false
      },
      gvnic: {
        enabled: false
      },
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {
        cgroupMode: '',
        sysctls: {}
      },
      localNvmeSsdBlockConfig: {
        localSsdCount: 0
      },
      localSsdCount: 0,
      loggingConfig: {
        variantConfig: {
          variant: ''
        }
      },
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {
        consumeReservationType: '',
        key: '',
        values: []
      },
      resourceLabels: {},
      sandboxConfig: {
        sandboxType: '',
        type: ''
      },
      serviceAccount: '',
      shieldedInstanceConfig: {
        enableIntegrityMonitoring: false,
        enableSecureBoot: false
      },
      spot: false,
      tags: [],
      taints: [
        {
          effect: '',
          key: '',
          value: ''
        }
      ],
      windowsNodeConfig: {
        osVersion: ''
      },
      workloadMetadataConfig: {
        mode: '',
        nodeMetadata: ''
      }
    },
    etag: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    locations: [],
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {
        autoUpgradeStartTime: '',
        description: ''
      }
    },
    maxPodsConstraint: {
      maxPodsPerNode: ''
    },
    name: '',
    networkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {
        externalIpEgressBandwidthTier: '',
        totalEgressBandwidthTier: ''
      },
      podCidrOverprovisionConfig: {
        disable: false
      },
      podIpv4CidrBlock: '',
      podRange: ''
    },
    placementPolicy: {
      type: ''
    },
    podIpv4CidrSize: 0,
    selfLink: '',
    status: '',
    statusMessage: '',
    updateInfo: {
      blueGreenInfo: {
        blueInstanceGroupUrls: [],
        bluePoolDeletionStartTime: '',
        greenInstanceGroupUrls: [],
        greenPoolVersion: '',
        phase: ''
      }
    },
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {
          batchNodeCount: 0,
          batchPercentage: '',
          batchSoakDuration: ''
        }
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    version: ''
  },
  parent: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/nodePools',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    nodePool: {
      autoscaling: {
        autoprovisioned: false,
        enabled: false,
        locationPolicy: '',
        maxNodeCount: 0,
        minNodeCount: 0,
        totalMaxNodeCount: 0,
        totalMinNodeCount: 0
      },
      conditions: [{canonicalCode: '', code: '', message: ''}],
      config: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {enabled: false},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      etag: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      locations: [],
      management: {
        autoRepair: false,
        autoUpgrade: false,
        upgradeOptions: {autoUpgradeStartTime: '', description: ''}
      },
      maxPodsConstraint: {maxPodsPerNode: ''},
      name: '',
      networkConfig: {
        createPodRange: false,
        enablePrivateNodes: false,
        networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
        podCidrOverprovisionConfig: {disable: false},
        podIpv4CidrBlock: '',
        podRange: ''
      },
      placementPolicy: {type: ''},
      podIpv4CidrSize: 0,
      selfLink: '',
      status: '',
      statusMessage: '',
      updateInfo: {
        blueGreenInfo: {
          blueInstanceGroupUrls: [],
          bluePoolDeletionStartTime: '',
          greenInstanceGroupUrls: [],
          greenPoolVersion: '',
          phase: ''
        }
      },
      upgradeSettings: {
        blueGreenSettings: {
          nodePoolSoakDuration: '',
          standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
        },
        maxSurge: 0,
        maxUnavailable: 0,
        strategy: ''
      },
      version: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent/nodePools';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","nodePool":{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"conditions":[{"canonicalCode":"","code":"","message":""}],"config":{"accelerators":[{"acceleratorCount":"","acceleratorType":"","gpuPartitionSize":"","gpuSharingConfig":{"gpuSharingStrategy":"","maxSharedClientsPerGpu":""},"maxTimeSharedClientsPerGpu":""}],"advancedMachineFeatures":{"threadsPerCore":""},"bootDiskKmsKey":"","confidentialNodes":{"enabled":false},"diskSizeGb":0,"diskType":"","ephemeralStorageConfig":{"localSsdCount":0},"ephemeralStorageLocalSsdConfig":{"localSsdCount":0},"fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"localNvmeSsdBlockConfig":{"localSsdCount":0},"localSsdCount":0,"loggingConfig":{"variantConfig":{"variant":""}},"machineType":"","metadata":{},"minCpuPlatform":"","nodeGroup":"","oauthScopes":[],"preemptible":false,"reservationAffinity":{"consumeReservationType":"","key":"","values":[]},"resourceLabels":{},"sandboxConfig":{"sandboxType":"","type":""},"serviceAccount":"","shieldedInstanceConfig":{"enableIntegrityMonitoring":false,"enableSecureBoot":false},"spot":false,"tags":[],"taints":[{"effect":"","key":"","value":""}],"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""}},"etag":"","initialNodeCount":0,"instanceGroupUrls":[],"locations":[],"management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"maxPodsConstraint":{"maxPodsPerNode":""},"name":"","networkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{"disable":false},"podIpv4CidrBlock":"","podRange":""},"placementPolicy":{"type":""},"podIpv4CidrSize":0,"selfLink":"","status":"","statusMessage":"","updateInfo":{"blueGreenInfo":{"blueInstanceGroupUrls":[],"bluePoolDeletionStartTime":"","greenInstanceGroupUrls":[],"greenPoolVersion":"","phase":""}},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""},"version":""},"parent":"","projectId":"","zone":""}'
};

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}}/v1beta1/:parent/nodePools',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "nodePool": {\n    "autoscaling": {\n      "autoprovisioned": false,\n      "enabled": false,\n      "locationPolicy": "",\n      "maxNodeCount": 0,\n      "minNodeCount": 0,\n      "totalMaxNodeCount": 0,\n      "totalMinNodeCount": 0\n    },\n    "conditions": [\n      {\n        "canonicalCode": "",\n        "code": "",\n        "message": ""\n      }\n    ],\n    "config": {\n      "accelerators": [\n        {\n          "acceleratorCount": "",\n          "acceleratorType": "",\n          "gpuPartitionSize": "",\n          "gpuSharingConfig": {\n            "gpuSharingStrategy": "",\n            "maxSharedClientsPerGpu": ""\n          },\n          "maxTimeSharedClientsPerGpu": ""\n        }\n      ],\n      "advancedMachineFeatures": {\n        "threadsPerCore": ""\n      },\n      "bootDiskKmsKey": "",\n      "confidentialNodes": {\n        "enabled": false\n      },\n      "diskSizeGb": 0,\n      "diskType": "",\n      "ephemeralStorageConfig": {\n        "localSsdCount": 0\n      },\n      "ephemeralStorageLocalSsdConfig": {\n        "localSsdCount": 0\n      },\n      "fastSocket": {\n        "enabled": false\n      },\n      "gcfsConfig": {\n        "enabled": false\n      },\n      "gvnic": {\n        "enabled": false\n      },\n      "imageType": "",\n      "kubeletConfig": {\n        "cpuCfsQuota": false,\n        "cpuCfsQuotaPeriod": "",\n        "cpuManagerPolicy": "",\n        "podPidsLimit": ""\n      },\n      "labels": {},\n      "linuxNodeConfig": {\n        "cgroupMode": "",\n        "sysctls": {}\n      },\n      "localNvmeSsdBlockConfig": {\n        "localSsdCount": 0\n      },\n      "localSsdCount": 0,\n      "loggingConfig": {\n        "variantConfig": {\n          "variant": ""\n        }\n      },\n      "machineType": "",\n      "metadata": {},\n      "minCpuPlatform": "",\n      "nodeGroup": "",\n      "oauthScopes": [],\n      "preemptible": false,\n      "reservationAffinity": {\n        "consumeReservationType": "",\n        "key": "",\n        "values": []\n      },\n      "resourceLabels": {},\n      "sandboxConfig": {\n        "sandboxType": "",\n        "type": ""\n      },\n      "serviceAccount": "",\n      "shieldedInstanceConfig": {\n        "enableIntegrityMonitoring": false,\n        "enableSecureBoot": false\n      },\n      "spot": false,\n      "tags": [],\n      "taints": [\n        {\n          "effect": "",\n          "key": "",\n          "value": ""\n        }\n      ],\n      "windowsNodeConfig": {\n        "osVersion": ""\n      },\n      "workloadMetadataConfig": {\n        "mode": "",\n        "nodeMetadata": ""\n      }\n    },\n    "etag": "",\n    "initialNodeCount": 0,\n    "instanceGroupUrls": [],\n    "locations": [],\n    "management": {\n      "autoRepair": false,\n      "autoUpgrade": false,\n      "upgradeOptions": {\n        "autoUpgradeStartTime": "",\n        "description": ""\n      }\n    },\n    "maxPodsConstraint": {\n      "maxPodsPerNode": ""\n    },\n    "name": "",\n    "networkConfig": {\n      "createPodRange": false,\n      "enablePrivateNodes": false,\n      "networkPerformanceConfig": {\n        "externalIpEgressBandwidthTier": "",\n        "totalEgressBandwidthTier": ""\n      },\n      "podCidrOverprovisionConfig": {\n        "disable": false\n      },\n      "podIpv4CidrBlock": "",\n      "podRange": ""\n    },\n    "placementPolicy": {\n      "type": ""\n    },\n    "podIpv4CidrSize": 0,\n    "selfLink": "",\n    "status": "",\n    "statusMessage": "",\n    "updateInfo": {\n      "blueGreenInfo": {\n        "blueInstanceGroupUrls": [],\n        "bluePoolDeletionStartTime": "",\n        "greenInstanceGroupUrls": [],\n        "greenPoolVersion": "",\n        "phase": ""\n      }\n    },\n    "upgradeSettings": {\n      "blueGreenSettings": {\n        "nodePoolSoakDuration": "",\n        "standardRolloutPolicy": {\n          "batchNodeCount": 0,\n          "batchPercentage": "",\n          "batchSoakDuration": ""\n        }\n      },\n      "maxSurge": 0,\n      "maxUnavailable": 0,\n      "strategy": ""\n    },\n    "version": ""\n  },\n  "parent": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/nodePools")
  .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/v1beta1/:parent/nodePools',
  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({
  clusterId: '',
  nodePool: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    conditions: [{canonicalCode: '', code: '', message: ''}],
    config: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {threadsPerCore: ''},
      bootDiskKmsKey: '',
      confidentialNodes: {enabled: false},
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {localSsdCount: 0},
      ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
      fastSocket: {enabled: false},
      gcfsConfig: {enabled: false},
      gvnic: {enabled: false},
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {cgroupMode: '', sysctls: {}},
      localNvmeSsdBlockConfig: {localSsdCount: 0},
      localSsdCount: 0,
      loggingConfig: {variantConfig: {variant: ''}},
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {consumeReservationType: '', key: '', values: []},
      resourceLabels: {},
      sandboxConfig: {sandboxType: '', type: ''},
      serviceAccount: '',
      shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
      spot: false,
      tags: [],
      taints: [{effect: '', key: '', value: ''}],
      windowsNodeConfig: {osVersion: ''},
      workloadMetadataConfig: {mode: '', nodeMetadata: ''}
    },
    etag: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    locations: [],
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {autoUpgradeStartTime: '', description: ''}
    },
    maxPodsConstraint: {maxPodsPerNode: ''},
    name: '',
    networkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
      podCidrOverprovisionConfig: {disable: false},
      podIpv4CidrBlock: '',
      podRange: ''
    },
    placementPolicy: {type: ''},
    podIpv4CidrSize: 0,
    selfLink: '',
    status: '',
    statusMessage: '',
    updateInfo: {
      blueGreenInfo: {
        blueInstanceGroupUrls: [],
        bluePoolDeletionStartTime: '',
        greenInstanceGroupUrls: [],
        greenPoolVersion: '',
        phase: ''
      }
    },
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    version: ''
  },
  parent: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/nodePools',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    nodePool: {
      autoscaling: {
        autoprovisioned: false,
        enabled: false,
        locationPolicy: '',
        maxNodeCount: 0,
        minNodeCount: 0,
        totalMaxNodeCount: 0,
        totalMinNodeCount: 0
      },
      conditions: [{canonicalCode: '', code: '', message: ''}],
      config: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {enabled: false},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      etag: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      locations: [],
      management: {
        autoRepair: false,
        autoUpgrade: false,
        upgradeOptions: {autoUpgradeStartTime: '', description: ''}
      },
      maxPodsConstraint: {maxPodsPerNode: ''},
      name: '',
      networkConfig: {
        createPodRange: false,
        enablePrivateNodes: false,
        networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
        podCidrOverprovisionConfig: {disable: false},
        podIpv4CidrBlock: '',
        podRange: ''
      },
      placementPolicy: {type: ''},
      podIpv4CidrSize: 0,
      selfLink: '',
      status: '',
      statusMessage: '',
      updateInfo: {
        blueGreenInfo: {
          blueInstanceGroupUrls: [],
          bluePoolDeletionStartTime: '',
          greenInstanceGroupUrls: [],
          greenPoolVersion: '',
          phase: ''
        }
      },
      upgradeSettings: {
        blueGreenSettings: {
          nodePoolSoakDuration: '',
          standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
        },
        maxSurge: 0,
        maxUnavailable: 0,
        strategy: ''
      },
      version: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/:parent/nodePools');

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

req.type('json');
req.send({
  clusterId: '',
  nodePool: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    conditions: [
      {
        canonicalCode: '',
        code: '',
        message: ''
      }
    ],
    config: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {
            gpuSharingStrategy: '',
            maxSharedClientsPerGpu: ''
          },
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {
        threadsPerCore: ''
      },
      bootDiskKmsKey: '',
      confidentialNodes: {
        enabled: false
      },
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {
        localSsdCount: 0
      },
      ephemeralStorageLocalSsdConfig: {
        localSsdCount: 0
      },
      fastSocket: {
        enabled: false
      },
      gcfsConfig: {
        enabled: false
      },
      gvnic: {
        enabled: false
      },
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {
        cgroupMode: '',
        sysctls: {}
      },
      localNvmeSsdBlockConfig: {
        localSsdCount: 0
      },
      localSsdCount: 0,
      loggingConfig: {
        variantConfig: {
          variant: ''
        }
      },
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {
        consumeReservationType: '',
        key: '',
        values: []
      },
      resourceLabels: {},
      sandboxConfig: {
        sandboxType: '',
        type: ''
      },
      serviceAccount: '',
      shieldedInstanceConfig: {
        enableIntegrityMonitoring: false,
        enableSecureBoot: false
      },
      spot: false,
      tags: [],
      taints: [
        {
          effect: '',
          key: '',
          value: ''
        }
      ],
      windowsNodeConfig: {
        osVersion: ''
      },
      workloadMetadataConfig: {
        mode: '',
        nodeMetadata: ''
      }
    },
    etag: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    locations: [],
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {
        autoUpgradeStartTime: '',
        description: ''
      }
    },
    maxPodsConstraint: {
      maxPodsPerNode: ''
    },
    name: '',
    networkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {
        externalIpEgressBandwidthTier: '',
        totalEgressBandwidthTier: ''
      },
      podCidrOverprovisionConfig: {
        disable: false
      },
      podIpv4CidrBlock: '',
      podRange: ''
    },
    placementPolicy: {
      type: ''
    },
    podIpv4CidrSize: 0,
    selfLink: '',
    status: '',
    statusMessage: '',
    updateInfo: {
      blueGreenInfo: {
        blueInstanceGroupUrls: [],
        bluePoolDeletionStartTime: '',
        greenInstanceGroupUrls: [],
        greenPoolVersion: '',
        phase: ''
      }
    },
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {
          batchNodeCount: 0,
          batchPercentage: '',
          batchSoakDuration: ''
        }
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    version: ''
  },
  parent: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:parent/nodePools',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    nodePool: {
      autoscaling: {
        autoprovisioned: false,
        enabled: false,
        locationPolicy: '',
        maxNodeCount: 0,
        minNodeCount: 0,
        totalMaxNodeCount: 0,
        totalMinNodeCount: 0
      },
      conditions: [{canonicalCode: '', code: '', message: ''}],
      config: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {enabled: false},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      etag: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      locations: [],
      management: {
        autoRepair: false,
        autoUpgrade: false,
        upgradeOptions: {autoUpgradeStartTime: '', description: ''}
      },
      maxPodsConstraint: {maxPodsPerNode: ''},
      name: '',
      networkConfig: {
        createPodRange: false,
        enablePrivateNodes: false,
        networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
        podCidrOverprovisionConfig: {disable: false},
        podIpv4CidrBlock: '',
        podRange: ''
      },
      placementPolicy: {type: ''},
      podIpv4CidrSize: 0,
      selfLink: '',
      status: '',
      statusMessage: '',
      updateInfo: {
        blueGreenInfo: {
          blueInstanceGroupUrls: [],
          bluePoolDeletionStartTime: '',
          greenInstanceGroupUrls: [],
          greenPoolVersion: '',
          phase: ''
        }
      },
      upgradeSettings: {
        blueGreenSettings: {
          nodePoolSoakDuration: '',
          standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
        },
        maxSurge: 0,
        maxUnavailable: 0,
        strategy: ''
      },
      version: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:parent/nodePools';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","nodePool":{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"conditions":[{"canonicalCode":"","code":"","message":""}],"config":{"accelerators":[{"acceleratorCount":"","acceleratorType":"","gpuPartitionSize":"","gpuSharingConfig":{"gpuSharingStrategy":"","maxSharedClientsPerGpu":""},"maxTimeSharedClientsPerGpu":""}],"advancedMachineFeatures":{"threadsPerCore":""},"bootDiskKmsKey":"","confidentialNodes":{"enabled":false},"diskSizeGb":0,"diskType":"","ephemeralStorageConfig":{"localSsdCount":0},"ephemeralStorageLocalSsdConfig":{"localSsdCount":0},"fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"localNvmeSsdBlockConfig":{"localSsdCount":0},"localSsdCount":0,"loggingConfig":{"variantConfig":{"variant":""}},"machineType":"","metadata":{},"minCpuPlatform":"","nodeGroup":"","oauthScopes":[],"preemptible":false,"reservationAffinity":{"consumeReservationType":"","key":"","values":[]},"resourceLabels":{},"sandboxConfig":{"sandboxType":"","type":""},"serviceAccount":"","shieldedInstanceConfig":{"enableIntegrityMonitoring":false,"enableSecureBoot":false},"spot":false,"tags":[],"taints":[{"effect":"","key":"","value":""}],"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""}},"etag":"","initialNodeCount":0,"instanceGroupUrls":[],"locations":[],"management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"maxPodsConstraint":{"maxPodsPerNode":""},"name":"","networkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{"disable":false},"podIpv4CidrBlock":"","podRange":""},"placementPolicy":{"type":""},"podIpv4CidrSize":0,"selfLink":"","status":"","statusMessage":"","updateInfo":{"blueGreenInfo":{"blueInstanceGroupUrls":[],"bluePoolDeletionStartTime":"","greenInstanceGroupUrls":[],"greenPoolVersion":"","phase":""}},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""},"version":""},"parent":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"nodePool": @{ @"autoscaling": @{ @"autoprovisioned": @NO, @"enabled": @NO, @"locationPolicy": @"", @"maxNodeCount": @0, @"minNodeCount": @0, @"totalMaxNodeCount": @0, @"totalMinNodeCount": @0 }, @"conditions": @[ @{ @"canonicalCode": @"", @"code": @"", @"message": @"" } ], @"config": @{ @"accelerators": @[ @{ @"acceleratorCount": @"", @"acceleratorType": @"", @"gpuPartitionSize": @"", @"gpuSharingConfig": @{ @"gpuSharingStrategy": @"", @"maxSharedClientsPerGpu": @"" }, @"maxTimeSharedClientsPerGpu": @"" } ], @"advancedMachineFeatures": @{ @"threadsPerCore": @"" }, @"bootDiskKmsKey": @"", @"confidentialNodes": @{ @"enabled": @NO }, @"diskSizeGb": @0, @"diskType": @"", @"ephemeralStorageConfig": @{ @"localSsdCount": @0 }, @"ephemeralStorageLocalSsdConfig": @{ @"localSsdCount": @0 }, @"fastSocket": @{ @"enabled": @NO }, @"gcfsConfig": @{ @"enabled": @NO }, @"gvnic": @{ @"enabled": @NO }, @"imageType": @"", @"kubeletConfig": @{ @"cpuCfsQuota": @NO, @"cpuCfsQuotaPeriod": @"", @"cpuManagerPolicy": @"", @"podPidsLimit": @"" }, @"labels": @{  }, @"linuxNodeConfig": @{ @"cgroupMode": @"", @"sysctls": @{  } }, @"localNvmeSsdBlockConfig": @{ @"localSsdCount": @0 }, @"localSsdCount": @0, @"loggingConfig": @{ @"variantConfig": @{ @"variant": @"" } }, @"machineType": @"", @"metadata": @{  }, @"minCpuPlatform": @"", @"nodeGroup": @"", @"oauthScopes": @[  ], @"preemptible": @NO, @"reservationAffinity": @{ @"consumeReservationType": @"", @"key": @"", @"values": @[  ] }, @"resourceLabels": @{  }, @"sandboxConfig": @{ @"sandboxType": @"", @"type": @"" }, @"serviceAccount": @"", @"shieldedInstanceConfig": @{ @"enableIntegrityMonitoring": @NO, @"enableSecureBoot": @NO }, @"spot": @NO, @"tags": @[  ], @"taints": @[ @{ @"effect": @"", @"key": @"", @"value": @"" } ], @"windowsNodeConfig": @{ @"osVersion": @"" }, @"workloadMetadataConfig": @{ @"mode": @"", @"nodeMetadata": @"" } }, @"etag": @"", @"initialNodeCount": @0, @"instanceGroupUrls": @[  ], @"locations": @[  ], @"management": @{ @"autoRepair": @NO, @"autoUpgrade": @NO, @"upgradeOptions": @{ @"autoUpgradeStartTime": @"", @"description": @"" } }, @"maxPodsConstraint": @{ @"maxPodsPerNode": @"" }, @"name": @"", @"networkConfig": @{ @"createPodRange": @NO, @"enablePrivateNodes": @NO, @"networkPerformanceConfig": @{ @"externalIpEgressBandwidthTier": @"", @"totalEgressBandwidthTier": @"" }, @"podCidrOverprovisionConfig": @{ @"disable": @NO }, @"podIpv4CidrBlock": @"", @"podRange": @"" }, @"placementPolicy": @{ @"type": @"" }, @"podIpv4CidrSize": @0, @"selfLink": @"", @"status": @"", @"statusMessage": @"", @"updateInfo": @{ @"blueGreenInfo": @{ @"blueInstanceGroupUrls": @[  ], @"bluePoolDeletionStartTime": @"", @"greenInstanceGroupUrls": @[  ], @"greenPoolVersion": @"", @"phase": @"" } }, @"upgradeSettings": @{ @"blueGreenSettings": @{ @"nodePoolSoakDuration": @"", @"standardRolloutPolicy": @{ @"batchNodeCount": @0, @"batchPercentage": @"", @"batchSoakDuration": @"" } }, @"maxSurge": @0, @"maxUnavailable": @0, @"strategy": @"" }, @"version": @"" },
                              @"parent": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:parent/nodePools"]
                                                       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}}/v1beta1/:parent/nodePools" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:parent/nodePools",
  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([
    'clusterId' => '',
    'nodePool' => [
        'autoscaling' => [
                'autoprovisioned' => null,
                'enabled' => null,
                'locationPolicy' => '',
                'maxNodeCount' => 0,
                'minNodeCount' => 0,
                'totalMaxNodeCount' => 0,
                'totalMinNodeCount' => 0
        ],
        'conditions' => [
                [
                                'canonicalCode' => '',
                                'code' => '',
                                'message' => ''
                ]
        ],
        'config' => [
                'accelerators' => [
                                [
                                                                'acceleratorCount' => '',
                                                                'acceleratorType' => '',
                                                                'gpuPartitionSize' => '',
                                                                'gpuSharingConfig' => [
                                                                                                                                'gpuSharingStrategy' => '',
                                                                                                                                'maxSharedClientsPerGpu' => ''
                                                                ],
                                                                'maxTimeSharedClientsPerGpu' => ''
                                ]
                ],
                'advancedMachineFeatures' => [
                                'threadsPerCore' => ''
                ],
                'bootDiskKmsKey' => '',
                'confidentialNodes' => [
                                'enabled' => null
                ],
                'diskSizeGb' => 0,
                'diskType' => '',
                'ephemeralStorageConfig' => [
                                'localSsdCount' => 0
                ],
                'ephemeralStorageLocalSsdConfig' => [
                                'localSsdCount' => 0
                ],
                'fastSocket' => [
                                'enabled' => null
                ],
                'gcfsConfig' => [
                                'enabled' => null
                ],
                'gvnic' => [
                                'enabled' => null
                ],
                'imageType' => '',
                'kubeletConfig' => [
                                'cpuCfsQuota' => null,
                                'cpuCfsQuotaPeriod' => '',
                                'cpuManagerPolicy' => '',
                                'podPidsLimit' => ''
                ],
                'labels' => [
                                
                ],
                'linuxNodeConfig' => [
                                'cgroupMode' => '',
                                'sysctls' => [
                                                                
                                ]
                ],
                'localNvmeSsdBlockConfig' => [
                                'localSsdCount' => 0
                ],
                'localSsdCount' => 0,
                'loggingConfig' => [
                                'variantConfig' => [
                                                                'variant' => ''
                                ]
                ],
                'machineType' => '',
                'metadata' => [
                                
                ],
                'minCpuPlatform' => '',
                'nodeGroup' => '',
                'oauthScopes' => [
                                
                ],
                'preemptible' => null,
                'reservationAffinity' => [
                                'consumeReservationType' => '',
                                'key' => '',
                                'values' => [
                                                                
                                ]
                ],
                'resourceLabels' => [
                                
                ],
                'sandboxConfig' => [
                                'sandboxType' => '',
                                'type' => ''
                ],
                'serviceAccount' => '',
                'shieldedInstanceConfig' => [
                                'enableIntegrityMonitoring' => null,
                                'enableSecureBoot' => null
                ],
                'spot' => null,
                'tags' => [
                                
                ],
                'taints' => [
                                [
                                                                'effect' => '',
                                                                'key' => '',
                                                                'value' => ''
                                ]
                ],
                'windowsNodeConfig' => [
                                'osVersion' => ''
                ],
                'workloadMetadataConfig' => [
                                'mode' => '',
                                'nodeMetadata' => ''
                ]
        ],
        'etag' => '',
        'initialNodeCount' => 0,
        'instanceGroupUrls' => [
                
        ],
        'locations' => [
                
        ],
        'management' => [
                'autoRepair' => null,
                'autoUpgrade' => null,
                'upgradeOptions' => [
                                'autoUpgradeStartTime' => '',
                                'description' => ''
                ]
        ],
        'maxPodsConstraint' => [
                'maxPodsPerNode' => ''
        ],
        'name' => '',
        'networkConfig' => [
                'createPodRange' => null,
                'enablePrivateNodes' => null,
                'networkPerformanceConfig' => [
                                'externalIpEgressBandwidthTier' => '',
                                'totalEgressBandwidthTier' => ''
                ],
                'podCidrOverprovisionConfig' => [
                                'disable' => null
                ],
                'podIpv4CidrBlock' => '',
                'podRange' => ''
        ],
        'placementPolicy' => [
                'type' => ''
        ],
        'podIpv4CidrSize' => 0,
        'selfLink' => '',
        'status' => '',
        'statusMessage' => '',
        'updateInfo' => [
                'blueGreenInfo' => [
                                'blueInstanceGroupUrls' => [
                                                                
                                ],
                                'bluePoolDeletionStartTime' => '',
                                'greenInstanceGroupUrls' => [
                                                                
                                ],
                                'greenPoolVersion' => '',
                                'phase' => ''
                ]
        ],
        'upgradeSettings' => [
                'blueGreenSettings' => [
                                'nodePoolSoakDuration' => '',
                                'standardRolloutPolicy' => [
                                                                'batchNodeCount' => 0,
                                                                'batchPercentage' => '',
                                                                'batchSoakDuration' => ''
                                ]
                ],
                'maxSurge' => 0,
                'maxUnavailable' => 0,
                'strategy' => ''
        ],
        'version' => ''
    ],
    'parent' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:parent/nodePools', [
  'body' => '{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'nodePool' => [
    'autoscaling' => [
        'autoprovisioned' => null,
        'enabled' => null,
        'locationPolicy' => '',
        'maxNodeCount' => 0,
        'minNodeCount' => 0,
        'totalMaxNodeCount' => 0,
        'totalMinNodeCount' => 0
    ],
    'conditions' => [
        [
                'canonicalCode' => '',
                'code' => '',
                'message' => ''
        ]
    ],
    'config' => [
        'accelerators' => [
                [
                                'acceleratorCount' => '',
                                'acceleratorType' => '',
                                'gpuPartitionSize' => '',
                                'gpuSharingConfig' => [
                                                                'gpuSharingStrategy' => '',
                                                                'maxSharedClientsPerGpu' => ''
                                ],
                                'maxTimeSharedClientsPerGpu' => ''
                ]
        ],
        'advancedMachineFeatures' => [
                'threadsPerCore' => ''
        ],
        'bootDiskKmsKey' => '',
        'confidentialNodes' => [
                'enabled' => null
        ],
        'diskSizeGb' => 0,
        'diskType' => '',
        'ephemeralStorageConfig' => [
                'localSsdCount' => 0
        ],
        'ephemeralStorageLocalSsdConfig' => [
                'localSsdCount' => 0
        ],
        'fastSocket' => [
                'enabled' => null
        ],
        'gcfsConfig' => [
                'enabled' => null
        ],
        'gvnic' => [
                'enabled' => null
        ],
        'imageType' => '',
        'kubeletConfig' => [
                'cpuCfsQuota' => null,
                'cpuCfsQuotaPeriod' => '',
                'cpuManagerPolicy' => '',
                'podPidsLimit' => ''
        ],
        'labels' => [
                
        ],
        'linuxNodeConfig' => [
                'cgroupMode' => '',
                'sysctls' => [
                                
                ]
        ],
        'localNvmeSsdBlockConfig' => [
                'localSsdCount' => 0
        ],
        'localSsdCount' => 0,
        'loggingConfig' => [
                'variantConfig' => [
                                'variant' => ''
                ]
        ],
        'machineType' => '',
        'metadata' => [
                
        ],
        'minCpuPlatform' => '',
        'nodeGroup' => '',
        'oauthScopes' => [
                
        ],
        'preemptible' => null,
        'reservationAffinity' => [
                'consumeReservationType' => '',
                'key' => '',
                'values' => [
                                
                ]
        ],
        'resourceLabels' => [
                
        ],
        'sandboxConfig' => [
                'sandboxType' => '',
                'type' => ''
        ],
        'serviceAccount' => '',
        'shieldedInstanceConfig' => [
                'enableIntegrityMonitoring' => null,
                'enableSecureBoot' => null
        ],
        'spot' => null,
        'tags' => [
                
        ],
        'taints' => [
                [
                                'effect' => '',
                                'key' => '',
                                'value' => ''
                ]
        ],
        'windowsNodeConfig' => [
                'osVersion' => ''
        ],
        'workloadMetadataConfig' => [
                'mode' => '',
                'nodeMetadata' => ''
        ]
    ],
    'etag' => '',
    'initialNodeCount' => 0,
    'instanceGroupUrls' => [
        
    ],
    'locations' => [
        
    ],
    'management' => [
        'autoRepair' => null,
        'autoUpgrade' => null,
        'upgradeOptions' => [
                'autoUpgradeStartTime' => '',
                'description' => ''
        ]
    ],
    'maxPodsConstraint' => [
        'maxPodsPerNode' => ''
    ],
    'name' => '',
    'networkConfig' => [
        'createPodRange' => null,
        'enablePrivateNodes' => null,
        'networkPerformanceConfig' => [
                'externalIpEgressBandwidthTier' => '',
                'totalEgressBandwidthTier' => ''
        ],
        'podCidrOverprovisionConfig' => [
                'disable' => null
        ],
        'podIpv4CidrBlock' => '',
        'podRange' => ''
    ],
    'placementPolicy' => [
        'type' => ''
    ],
    'podIpv4CidrSize' => 0,
    'selfLink' => '',
    'status' => '',
    'statusMessage' => '',
    'updateInfo' => [
        'blueGreenInfo' => [
                'blueInstanceGroupUrls' => [
                                
                ],
                'bluePoolDeletionStartTime' => '',
                'greenInstanceGroupUrls' => [
                                
                ],
                'greenPoolVersion' => '',
                'phase' => ''
        ]
    ],
    'upgradeSettings' => [
        'blueGreenSettings' => [
                'nodePoolSoakDuration' => '',
                'standardRolloutPolicy' => [
                                'batchNodeCount' => 0,
                                'batchPercentage' => '',
                                'batchSoakDuration' => ''
                ]
        ],
        'maxSurge' => 0,
        'maxUnavailable' => 0,
        'strategy' => ''
    ],
    'version' => ''
  ],
  'parent' => '',
  'projectId' => '',
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'nodePool' => [
    'autoscaling' => [
        'autoprovisioned' => null,
        'enabled' => null,
        'locationPolicy' => '',
        'maxNodeCount' => 0,
        'minNodeCount' => 0,
        'totalMaxNodeCount' => 0,
        'totalMinNodeCount' => 0
    ],
    'conditions' => [
        [
                'canonicalCode' => '',
                'code' => '',
                'message' => ''
        ]
    ],
    'config' => [
        'accelerators' => [
                [
                                'acceleratorCount' => '',
                                'acceleratorType' => '',
                                'gpuPartitionSize' => '',
                                'gpuSharingConfig' => [
                                                                'gpuSharingStrategy' => '',
                                                                'maxSharedClientsPerGpu' => ''
                                ],
                                'maxTimeSharedClientsPerGpu' => ''
                ]
        ],
        'advancedMachineFeatures' => [
                'threadsPerCore' => ''
        ],
        'bootDiskKmsKey' => '',
        'confidentialNodes' => [
                'enabled' => null
        ],
        'diskSizeGb' => 0,
        'diskType' => '',
        'ephemeralStorageConfig' => [
                'localSsdCount' => 0
        ],
        'ephemeralStorageLocalSsdConfig' => [
                'localSsdCount' => 0
        ],
        'fastSocket' => [
                'enabled' => null
        ],
        'gcfsConfig' => [
                'enabled' => null
        ],
        'gvnic' => [
                'enabled' => null
        ],
        'imageType' => '',
        'kubeletConfig' => [
                'cpuCfsQuota' => null,
                'cpuCfsQuotaPeriod' => '',
                'cpuManagerPolicy' => '',
                'podPidsLimit' => ''
        ],
        'labels' => [
                
        ],
        'linuxNodeConfig' => [
                'cgroupMode' => '',
                'sysctls' => [
                                
                ]
        ],
        'localNvmeSsdBlockConfig' => [
                'localSsdCount' => 0
        ],
        'localSsdCount' => 0,
        'loggingConfig' => [
                'variantConfig' => [
                                'variant' => ''
                ]
        ],
        'machineType' => '',
        'metadata' => [
                
        ],
        'minCpuPlatform' => '',
        'nodeGroup' => '',
        'oauthScopes' => [
                
        ],
        'preemptible' => null,
        'reservationAffinity' => [
                'consumeReservationType' => '',
                'key' => '',
                'values' => [
                                
                ]
        ],
        'resourceLabels' => [
                
        ],
        'sandboxConfig' => [
                'sandboxType' => '',
                'type' => ''
        ],
        'serviceAccount' => '',
        'shieldedInstanceConfig' => [
                'enableIntegrityMonitoring' => null,
                'enableSecureBoot' => null
        ],
        'spot' => null,
        'tags' => [
                
        ],
        'taints' => [
                [
                                'effect' => '',
                                'key' => '',
                                'value' => ''
                ]
        ],
        'windowsNodeConfig' => [
                'osVersion' => ''
        ],
        'workloadMetadataConfig' => [
                'mode' => '',
                'nodeMetadata' => ''
        ]
    ],
    'etag' => '',
    'initialNodeCount' => 0,
    'instanceGroupUrls' => [
        
    ],
    'locations' => [
        
    ],
    'management' => [
        'autoRepair' => null,
        'autoUpgrade' => null,
        'upgradeOptions' => [
                'autoUpgradeStartTime' => '',
                'description' => ''
        ]
    ],
    'maxPodsConstraint' => [
        'maxPodsPerNode' => ''
    ],
    'name' => '',
    'networkConfig' => [
        'createPodRange' => null,
        'enablePrivateNodes' => null,
        'networkPerformanceConfig' => [
                'externalIpEgressBandwidthTier' => '',
                'totalEgressBandwidthTier' => ''
        ],
        'podCidrOverprovisionConfig' => [
                'disable' => null
        ],
        'podIpv4CidrBlock' => '',
        'podRange' => ''
    ],
    'placementPolicy' => [
        'type' => ''
    ],
    'podIpv4CidrSize' => 0,
    'selfLink' => '',
    'status' => '',
    'statusMessage' => '',
    'updateInfo' => [
        'blueGreenInfo' => [
                'blueInstanceGroupUrls' => [
                                
                ],
                'bluePoolDeletionStartTime' => '',
                'greenInstanceGroupUrls' => [
                                
                ],
                'greenPoolVersion' => '',
                'phase' => ''
        ]
    ],
    'upgradeSettings' => [
        'blueGreenSettings' => [
                'nodePoolSoakDuration' => '',
                'standardRolloutPolicy' => [
                                'batchNodeCount' => 0,
                                'batchPercentage' => '',
                                'batchSoakDuration' => ''
                ]
        ],
        'maxSurge' => 0,
        'maxUnavailable' => 0,
        'strategy' => ''
    ],
    'version' => ''
  ],
  'parent' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:parent/nodePools');
$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}}/v1beta1/:parent/nodePools' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent/nodePools' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
import http.client

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

payload = "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:parent/nodePools", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:parent/nodePools"

payload = {
    "clusterId": "",
    "nodePool": {
        "autoscaling": {
            "autoprovisioned": False,
            "enabled": False,
            "locationPolicy": "",
            "maxNodeCount": 0,
            "minNodeCount": 0,
            "totalMaxNodeCount": 0,
            "totalMinNodeCount": 0
        },
        "conditions": [
            {
                "canonicalCode": "",
                "code": "",
                "message": ""
            }
        ],
        "config": {
            "accelerators": [
                {
                    "acceleratorCount": "",
                    "acceleratorType": "",
                    "gpuPartitionSize": "",
                    "gpuSharingConfig": {
                        "gpuSharingStrategy": "",
                        "maxSharedClientsPerGpu": ""
                    },
                    "maxTimeSharedClientsPerGpu": ""
                }
            ],
            "advancedMachineFeatures": { "threadsPerCore": "" },
            "bootDiskKmsKey": "",
            "confidentialNodes": { "enabled": False },
            "diskSizeGb": 0,
            "diskType": "",
            "ephemeralStorageConfig": { "localSsdCount": 0 },
            "ephemeralStorageLocalSsdConfig": { "localSsdCount": 0 },
            "fastSocket": { "enabled": False },
            "gcfsConfig": { "enabled": False },
            "gvnic": { "enabled": False },
            "imageType": "",
            "kubeletConfig": {
                "cpuCfsQuota": False,
                "cpuCfsQuotaPeriod": "",
                "cpuManagerPolicy": "",
                "podPidsLimit": ""
            },
            "labels": {},
            "linuxNodeConfig": {
                "cgroupMode": "",
                "sysctls": {}
            },
            "localNvmeSsdBlockConfig": { "localSsdCount": 0 },
            "localSsdCount": 0,
            "loggingConfig": { "variantConfig": { "variant": "" } },
            "machineType": "",
            "metadata": {},
            "minCpuPlatform": "",
            "nodeGroup": "",
            "oauthScopes": [],
            "preemptible": False,
            "reservationAffinity": {
                "consumeReservationType": "",
                "key": "",
                "values": []
            },
            "resourceLabels": {},
            "sandboxConfig": {
                "sandboxType": "",
                "type": ""
            },
            "serviceAccount": "",
            "shieldedInstanceConfig": {
                "enableIntegrityMonitoring": False,
                "enableSecureBoot": False
            },
            "spot": False,
            "tags": [],
            "taints": [
                {
                    "effect": "",
                    "key": "",
                    "value": ""
                }
            ],
            "windowsNodeConfig": { "osVersion": "" },
            "workloadMetadataConfig": {
                "mode": "",
                "nodeMetadata": ""
            }
        },
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {
            "autoRepair": False,
            "autoUpgrade": False,
            "upgradeOptions": {
                "autoUpgradeStartTime": "",
                "description": ""
            }
        },
        "maxPodsConstraint": { "maxPodsPerNode": "" },
        "name": "",
        "networkConfig": {
            "createPodRange": False,
            "enablePrivateNodes": False,
            "networkPerformanceConfig": {
                "externalIpEgressBandwidthTier": "",
                "totalEgressBandwidthTier": ""
            },
            "podCidrOverprovisionConfig": { "disable": False },
            "podIpv4CidrBlock": "",
            "podRange": ""
        },
        "placementPolicy": { "type": "" },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": { "blueGreenInfo": {
                "blueInstanceGroupUrls": [],
                "bluePoolDeletionStartTime": "",
                "greenInstanceGroupUrls": [],
                "greenPoolVersion": "",
                "phase": ""
            } },
        "upgradeSettings": {
            "blueGreenSettings": {
                "nodePoolSoakDuration": "",
                "standardRolloutPolicy": {
                    "batchNodeCount": 0,
                    "batchPercentage": "",
                    "batchSoakDuration": ""
                }
            },
            "maxSurge": 0,
            "maxUnavailable": 0,
            "strategy": ""
        },
        "version": ""
    },
    "parent": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:parent/nodePools"

payload <- "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:parent/nodePools")

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  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:parent/nodePools') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "nodePool": json!({
            "autoscaling": json!({
                "autoprovisioned": false,
                "enabled": false,
                "locationPolicy": "",
                "maxNodeCount": 0,
                "minNodeCount": 0,
                "totalMaxNodeCount": 0,
                "totalMinNodeCount": 0
            }),
            "conditions": (
                json!({
                    "canonicalCode": "",
                    "code": "",
                    "message": ""
                })
            ),
            "config": json!({
                "accelerators": (
                    json!({
                        "acceleratorCount": "",
                        "acceleratorType": "",
                        "gpuPartitionSize": "",
                        "gpuSharingConfig": json!({
                            "gpuSharingStrategy": "",
                            "maxSharedClientsPerGpu": ""
                        }),
                        "maxTimeSharedClientsPerGpu": ""
                    })
                ),
                "advancedMachineFeatures": json!({"threadsPerCore": ""}),
                "bootDiskKmsKey": "",
                "confidentialNodes": json!({"enabled": false}),
                "diskSizeGb": 0,
                "diskType": "",
                "ephemeralStorageConfig": json!({"localSsdCount": 0}),
                "ephemeralStorageLocalSsdConfig": json!({"localSsdCount": 0}),
                "fastSocket": json!({"enabled": false}),
                "gcfsConfig": json!({"enabled": false}),
                "gvnic": json!({"enabled": false}),
                "imageType": "",
                "kubeletConfig": json!({
                    "cpuCfsQuota": false,
                    "cpuCfsQuotaPeriod": "",
                    "cpuManagerPolicy": "",
                    "podPidsLimit": ""
                }),
                "labels": json!({}),
                "linuxNodeConfig": json!({
                    "cgroupMode": "",
                    "sysctls": json!({})
                }),
                "localNvmeSsdBlockConfig": json!({"localSsdCount": 0}),
                "localSsdCount": 0,
                "loggingConfig": json!({"variantConfig": json!({"variant": ""})}),
                "machineType": "",
                "metadata": json!({}),
                "minCpuPlatform": "",
                "nodeGroup": "",
                "oauthScopes": (),
                "preemptible": false,
                "reservationAffinity": json!({
                    "consumeReservationType": "",
                    "key": "",
                    "values": ()
                }),
                "resourceLabels": json!({}),
                "sandboxConfig": json!({
                    "sandboxType": "",
                    "type": ""
                }),
                "serviceAccount": "",
                "shieldedInstanceConfig": json!({
                    "enableIntegrityMonitoring": false,
                    "enableSecureBoot": false
                }),
                "spot": false,
                "tags": (),
                "taints": (
                    json!({
                        "effect": "",
                        "key": "",
                        "value": ""
                    })
                ),
                "windowsNodeConfig": json!({"osVersion": ""}),
                "workloadMetadataConfig": json!({
                    "mode": "",
                    "nodeMetadata": ""
                })
            }),
            "etag": "",
            "initialNodeCount": 0,
            "instanceGroupUrls": (),
            "locations": (),
            "management": json!({
                "autoRepair": false,
                "autoUpgrade": false,
                "upgradeOptions": json!({
                    "autoUpgradeStartTime": "",
                    "description": ""
                })
            }),
            "maxPodsConstraint": json!({"maxPodsPerNode": ""}),
            "name": "",
            "networkConfig": json!({
                "createPodRange": false,
                "enablePrivateNodes": false,
                "networkPerformanceConfig": json!({
                    "externalIpEgressBandwidthTier": "",
                    "totalEgressBandwidthTier": ""
                }),
                "podCidrOverprovisionConfig": json!({"disable": false}),
                "podIpv4CidrBlock": "",
                "podRange": ""
            }),
            "placementPolicy": json!({"type": ""}),
            "podIpv4CidrSize": 0,
            "selfLink": "",
            "status": "",
            "statusMessage": "",
            "updateInfo": json!({"blueGreenInfo": json!({
                    "blueInstanceGroupUrls": (),
                    "bluePoolDeletionStartTime": "",
                    "greenInstanceGroupUrls": (),
                    "greenPoolVersion": "",
                    "phase": ""
                })}),
            "upgradeSettings": json!({
                "blueGreenSettings": json!({
                    "nodePoolSoakDuration": "",
                    "standardRolloutPolicy": json!({
                        "batchNodeCount": 0,
                        "batchPercentage": "",
                        "batchSoakDuration": ""
                    })
                }),
                "maxSurge": 0,
                "maxUnavailable": 0,
                "strategy": ""
            }),
            "version": ""
        }),
        "parent": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:parent/nodePools \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:parent/nodePools \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "nodePool": {\n    "autoscaling": {\n      "autoprovisioned": false,\n      "enabled": false,\n      "locationPolicy": "",\n      "maxNodeCount": 0,\n      "minNodeCount": 0,\n      "totalMaxNodeCount": 0,\n      "totalMinNodeCount": 0\n    },\n    "conditions": [\n      {\n        "canonicalCode": "",\n        "code": "",\n        "message": ""\n      }\n    ],\n    "config": {\n      "accelerators": [\n        {\n          "acceleratorCount": "",\n          "acceleratorType": "",\n          "gpuPartitionSize": "",\n          "gpuSharingConfig": {\n            "gpuSharingStrategy": "",\n            "maxSharedClientsPerGpu": ""\n          },\n          "maxTimeSharedClientsPerGpu": ""\n        }\n      ],\n      "advancedMachineFeatures": {\n        "threadsPerCore": ""\n      },\n      "bootDiskKmsKey": "",\n      "confidentialNodes": {\n        "enabled": false\n      },\n      "diskSizeGb": 0,\n      "diskType": "",\n      "ephemeralStorageConfig": {\n        "localSsdCount": 0\n      },\n      "ephemeralStorageLocalSsdConfig": {\n        "localSsdCount": 0\n      },\n      "fastSocket": {\n        "enabled": false\n      },\n      "gcfsConfig": {\n        "enabled": false\n      },\n      "gvnic": {\n        "enabled": false\n      },\n      "imageType": "",\n      "kubeletConfig": {\n        "cpuCfsQuota": false,\n        "cpuCfsQuotaPeriod": "",\n        "cpuManagerPolicy": "",\n        "podPidsLimit": ""\n      },\n      "labels": {},\n      "linuxNodeConfig": {\n        "cgroupMode": "",\n        "sysctls": {}\n      },\n      "localNvmeSsdBlockConfig": {\n        "localSsdCount": 0\n      },\n      "localSsdCount": 0,\n      "loggingConfig": {\n        "variantConfig": {\n          "variant": ""\n        }\n      },\n      "machineType": "",\n      "metadata": {},\n      "minCpuPlatform": "",\n      "nodeGroup": "",\n      "oauthScopes": [],\n      "preemptible": false,\n      "reservationAffinity": {\n        "consumeReservationType": "",\n        "key": "",\n        "values": []\n      },\n      "resourceLabels": {},\n      "sandboxConfig": {\n        "sandboxType": "",\n        "type": ""\n      },\n      "serviceAccount": "",\n      "shieldedInstanceConfig": {\n        "enableIntegrityMonitoring": false,\n        "enableSecureBoot": false\n      },\n      "spot": false,\n      "tags": [],\n      "taints": [\n        {\n          "effect": "",\n          "key": "",\n          "value": ""\n        }\n      ],\n      "windowsNodeConfig": {\n        "osVersion": ""\n      },\n      "workloadMetadataConfig": {\n        "mode": "",\n        "nodeMetadata": ""\n      }\n    },\n    "etag": "",\n    "initialNodeCount": 0,\n    "instanceGroupUrls": [],\n    "locations": [],\n    "management": {\n      "autoRepair": false,\n      "autoUpgrade": false,\n      "upgradeOptions": {\n        "autoUpgradeStartTime": "",\n        "description": ""\n      }\n    },\n    "maxPodsConstraint": {\n      "maxPodsPerNode": ""\n    },\n    "name": "",\n    "networkConfig": {\n      "createPodRange": false,\n      "enablePrivateNodes": false,\n      "networkPerformanceConfig": {\n        "externalIpEgressBandwidthTier": "",\n        "totalEgressBandwidthTier": ""\n      },\n      "podCidrOverprovisionConfig": {\n        "disable": false\n      },\n      "podIpv4CidrBlock": "",\n      "podRange": ""\n    },\n    "placementPolicy": {\n      "type": ""\n    },\n    "podIpv4CidrSize": 0,\n    "selfLink": "",\n    "status": "",\n    "statusMessage": "",\n    "updateInfo": {\n      "blueGreenInfo": {\n        "blueInstanceGroupUrls": [],\n        "bluePoolDeletionStartTime": "",\n        "greenInstanceGroupUrls": [],\n        "greenPoolVersion": "",\n        "phase": ""\n      }\n    },\n    "upgradeSettings": {\n      "blueGreenSettings": {\n        "nodePoolSoakDuration": "",\n        "standardRolloutPolicy": {\n          "batchNodeCount": 0,\n          "batchPercentage": "",\n          "batchSoakDuration": ""\n        }\n      },\n      "maxSurge": 0,\n      "maxUnavailable": 0,\n      "strategy": ""\n    },\n    "version": ""\n  },\n  "parent": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/nodePools
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "nodePool": [
    "autoscaling": [
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    ],
    "conditions": [
      [
        "canonicalCode": "",
        "code": "",
        "message": ""
      ]
    ],
    "config": [
      "accelerators": [
        [
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": [
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          ],
          "maxTimeSharedClientsPerGpu": ""
        ]
      ],
      "advancedMachineFeatures": ["threadsPerCore": ""],
      "bootDiskKmsKey": "",
      "confidentialNodes": ["enabled": false],
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": ["localSsdCount": 0],
      "ephemeralStorageLocalSsdConfig": ["localSsdCount": 0],
      "fastSocket": ["enabled": false],
      "gcfsConfig": ["enabled": false],
      "gvnic": ["enabled": false],
      "imageType": "",
      "kubeletConfig": [
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      ],
      "labels": [],
      "linuxNodeConfig": [
        "cgroupMode": "",
        "sysctls": []
      ],
      "localNvmeSsdBlockConfig": ["localSsdCount": 0],
      "localSsdCount": 0,
      "loggingConfig": ["variantConfig": ["variant": ""]],
      "machineType": "",
      "metadata": [],
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": [
        "consumeReservationType": "",
        "key": "",
        "values": []
      ],
      "resourceLabels": [],
      "sandboxConfig": [
        "sandboxType": "",
        "type": ""
      ],
      "serviceAccount": "",
      "shieldedInstanceConfig": [
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      ],
      "spot": false,
      "tags": [],
      "taints": [
        [
          "effect": "",
          "key": "",
          "value": ""
        ]
      ],
      "windowsNodeConfig": ["osVersion": ""],
      "workloadMetadataConfig": [
        "mode": "",
        "nodeMetadata": ""
      ]
    ],
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": [
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": [
        "autoUpgradeStartTime": "",
        "description": ""
      ]
    ],
    "maxPodsConstraint": ["maxPodsPerNode": ""],
    "name": "",
    "networkConfig": [
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": [
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      ],
      "podCidrOverprovisionConfig": ["disable": false],
      "podIpv4CidrBlock": "",
      "podRange": ""
    ],
    "placementPolicy": ["type": ""],
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": ["blueGreenInfo": [
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      ]],
    "upgradeSettings": [
      "blueGreenSettings": [
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": [
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        ]
      ],
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    ],
    "version": ""
  ],
  "parent": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/nodePools")! 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 container.projects.locations.clusters.nodePools.delete
{{baseUrl}}/v1beta1/:name
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/:name");

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

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

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

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

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

func main() {

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

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

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

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

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

}
DELETE /baseUrl/v1beta1/:name HTTP/1.1
Host: example.com

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

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

Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name")
  .delete(null)
  .build();

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

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

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

xhr.open('DELETE', '{{baseUrl}}/v1beta1/:name');

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

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

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

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name")
  .delete(null)
  .build()

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

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

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

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

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

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

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

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

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

const req = unirest('DELETE', '{{baseUrl}}/v1beta1/:name');

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

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

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

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

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

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

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

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

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

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

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

curl_close($curl);

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

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

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

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

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

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

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

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

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

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

response = requests.delete(url)

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

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

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

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

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

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

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

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

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

response = conn.delete('/baseUrl/v1beta1/:name') do |req|
end

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

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "DELETE"

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

dataTask.resume()
GET container.projects.locations.clusters.nodePools.list
{{baseUrl}}/v1beta1/:parent/nodePools
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/v1beta1/:parent/nodePools")
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/nodePools"

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

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

func main() {

	url := "{{baseUrl}}/v1beta1/:parent/nodePools"

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/nodePools'};

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

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

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

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

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

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

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

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

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}}/v1beta1/:parent/nodePools'};

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/v1beta1/:parent/nodePools")

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

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

url = "{{baseUrl}}/v1beta1/:parent/nodePools"

response = requests.get(url)

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

url <- "{{baseUrl}}/v1beta1/:parent/nodePools"

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

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

url = URI("{{baseUrl}}/v1beta1/:parent/nodePools")

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

puts response.status
puts response.body
use reqwest;

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/nodePools")! 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 container.projects.locations.clusters.nodePools.rollback
{{baseUrl}}/v1beta1/:name:rollback
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:rollback" {:content-type :json
                                                                   :form-params {:clusterId ""
                                                                                 :name ""
                                                                                 :nodePoolId ""
                                                                                 :projectId ""
                                                                                 :respectPdb false
                                                                                 :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:rollback"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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}}/v1beta1/:name:rollback"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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}}/v1beta1/:name:rollback");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:rollback"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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/v1beta1/:name:rollback HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 111

{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:rollback")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:rollback"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:rollback")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:rollback")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  respectPdb: false,
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:rollback',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    respectPdb: false,
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:rollback';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","nodePoolId":"","projectId":"","respectPdb":false,"zone":""}'
};

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}}/v1beta1/:name:rollback',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "respectPdb": false,\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:rollback")
  .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/v1beta1/:name:rollback',
  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({
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  respectPdb: false,
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:rollback',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    respectPdb: false,
    zone: ''
  },
  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}}/v1beta1/:name:rollback');

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

req.type('json');
req.send({
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  respectPdb: false,
  zone: ''
});

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}}/v1beta1/:name:rollback',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    respectPdb: false,
    zone: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:name:rollback';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","nodePoolId":"","projectId":"","respectPdb":false,"zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"name": @"",
                              @"nodePoolId": @"",
                              @"projectId": @"",
                              @"respectPdb": @NO,
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:rollback"]
                                                       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}}/v1beta1/:name:rollback" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:rollback",
  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([
    'clusterId' => '',
    'name' => '',
    'nodePoolId' => '',
    'projectId' => '',
    'respectPdb' => null,
    'zone' => ''
  ]),
  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}}/v1beta1/:name:rollback', [
  'body' => '{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'respectPdb' => null,
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'respectPdb' => null,
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name:rollback');
$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}}/v1beta1/:name:rollback' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name:rollback' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}'
import http.client

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

payload = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:rollback", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:rollback"

payload = {
    "clusterId": "",
    "name": "",
    "nodePoolId": "",
    "projectId": "",
    "respectPdb": False,
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:rollback"

payload <- "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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}}/v1beta1/:name:rollback")

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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/v1beta1/:name:rollback') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "name": "",
        "nodePoolId": "",
        "projectId": "",
        "respectPdb": false,
        "zone": ""
    });

    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}}/v1beta1/:name:rollback \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}'
echo '{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:rollback \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "respectPdb": false,\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:rollback
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:rollback")! 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 container.projects.locations.clusters.nodePools.setAutoscaling
{{baseUrl}}/v1beta1/:name:setAutoscaling
QUERY PARAMS

name
BODY json

{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setAutoscaling" {:content-type :json
                                                                         :form-params {:autoscaling {:autoprovisioned false
                                                                                                     :enabled false
                                                                                                     :locationPolicy ""
                                                                                                     :maxNodeCount 0
                                                                                                     :minNodeCount 0
                                                                                                     :totalMaxNodeCount 0
                                                                                                     :totalMinNodeCount 0}
                                                                                       :clusterId ""
                                                                                       :name ""
                                                                                       :nodePoolId ""
                                                                                       :projectId ""
                                                                                       :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setAutoscaling"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setAutoscaling"),
    Content = new StringContent("{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setAutoscaling");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setAutoscaling"

	payload := strings.NewReader("{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setAutoscaling HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 291

{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setAutoscaling")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setAutoscaling"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setAutoscaling")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setAutoscaling")
  .header("content-type", "application/json")
  .body("{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  autoscaling: {
    autoprovisioned: false,
    enabled: false,
    locationPolicy: '',
    maxNodeCount: 0,
    minNodeCount: 0,
    totalMaxNodeCount: 0,
    totalMinNodeCount: 0
  },
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setAutoscaling',
  headers: {'content-type': 'application/json'},
  data: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setAutoscaling';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"clusterId":"","name":"","nodePoolId":"","projectId":"","zone":""}'
};

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}}/v1beta1/:name:setAutoscaling',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "autoscaling": {\n    "autoprovisioned": false,\n    "enabled": false,\n    "locationPolicy": "",\n    "maxNodeCount": 0,\n    "minNodeCount": 0,\n    "totalMaxNodeCount": 0,\n    "totalMinNodeCount": 0\n  },\n  "clusterId": "",\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setAutoscaling")
  .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/v1beta1/:name:setAutoscaling',
  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({
  autoscaling: {
    autoprovisioned: false,
    enabled: false,
    locationPolicy: '',
    maxNodeCount: 0,
    minNodeCount: 0,
    totalMaxNodeCount: 0,
    totalMinNodeCount: 0
  },
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setAutoscaling',
  headers: {'content-type': 'application/json'},
  body: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/:name:setAutoscaling');

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

req.type('json');
req.send({
  autoscaling: {
    autoprovisioned: false,
    enabled: false,
    locationPolicy: '',
    maxNodeCount: 0,
    minNodeCount: 0,
    totalMaxNodeCount: 0,
    totalMinNodeCount: 0
  },
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:setAutoscaling',
  headers: {'content-type': 'application/json'},
  data: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:name:setAutoscaling';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"clusterId":"","name":"","nodePoolId":"","projectId":"","zone":""}'
};

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 = @{ @"autoscaling": @{ @"autoprovisioned": @NO, @"enabled": @NO, @"locationPolicy": @"", @"maxNodeCount": @0, @"minNodeCount": @0, @"totalMaxNodeCount": @0, @"totalMinNodeCount": @0 },
                              @"clusterId": @"",
                              @"name": @"",
                              @"nodePoolId": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:setAutoscaling"]
                                                       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}}/v1beta1/:name:setAutoscaling" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setAutoscaling",
  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([
    'autoscaling' => [
        'autoprovisioned' => null,
        'enabled' => null,
        'locationPolicy' => '',
        'maxNodeCount' => 0,
        'minNodeCount' => 0,
        'totalMaxNodeCount' => 0,
        'totalMinNodeCount' => 0
    ],
    'clusterId' => '',
    'name' => '',
    'nodePoolId' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setAutoscaling', [
  'body' => '{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'autoscaling' => [
    'autoprovisioned' => null,
    'enabled' => null,
    'locationPolicy' => '',
    'maxNodeCount' => 0,
    'minNodeCount' => 0,
    'totalMaxNodeCount' => 0,
    'totalMinNodeCount' => 0
  ],
  'clusterId' => '',
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'autoscaling' => [
    'autoprovisioned' => null,
    'enabled' => null,
    'locationPolicy' => '',
    'maxNodeCount' => 0,
    'minNodeCount' => 0,
    'totalMaxNodeCount' => 0,
    'totalMinNodeCount' => 0
  ],
  'clusterId' => '',
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name:setAutoscaling');
$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}}/v1beta1/:name:setAutoscaling' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name:setAutoscaling' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
import http.client

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

payload = "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setAutoscaling", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setAutoscaling"

payload = {
    "autoscaling": {
        "autoprovisioned": False,
        "enabled": False,
        "locationPolicy": "",
        "maxNodeCount": 0,
        "minNodeCount": 0,
        "totalMaxNodeCount": 0,
        "totalMinNodeCount": 0
    },
    "clusterId": "",
    "name": "",
    "nodePoolId": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setAutoscaling"

payload <- "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setAutoscaling")

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  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setAutoscaling') do |req|
  req.body = "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "autoscaling": json!({
            "autoprovisioned": false,
            "enabled": false,
            "locationPolicy": "",
            "maxNodeCount": 0,
            "minNodeCount": 0,
            "totalMaxNodeCount": 0,
            "totalMinNodeCount": 0
        }),
        "clusterId": "",
        "name": "",
        "nodePoolId": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:setAutoscaling \
  --header 'content-type: application/json' \
  --data '{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setAutoscaling \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "autoscaling": {\n    "autoprovisioned": false,\n    "enabled": false,\n    "locationPolicy": "",\n    "maxNodeCount": 0,\n    "minNodeCount": 0,\n    "totalMaxNodeCount": 0,\n    "totalMinNodeCount": 0\n  },\n  "clusterId": "",\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setAutoscaling
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "autoscaling": [
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  ],
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setAutoscaling")! 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 container.projects.locations.clusters.nodePools.setManagement
{{baseUrl}}/v1beta1/:name:setManagement
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setManagement" {:content-type :json
                                                                        :form-params {:clusterId ""
                                                                                      :management {:autoRepair false
                                                                                                   :autoUpgrade false
                                                                                                   :upgradeOptions {:autoUpgradeStartTime ""
                                                                                                                    :description ""}}
                                                                                      :name ""
                                                                                      :nodePoolId ""
                                                                                      :projectId ""
                                                                                      :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setManagement"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setManagement"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setManagement");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setManagement"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setManagement HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 250

{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setManagement")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setManagement"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setManagement")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setManagement")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  management: {
    autoRepair: false,
    autoUpgrade: false,
    upgradeOptions: {
      autoUpgradeStartTime: '',
      description: ''
    }
  },
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setManagement',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {autoUpgradeStartTime: '', description: ''}
    },
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setManagement';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"name":"","nodePoolId":"","projectId":"","zone":""}'
};

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}}/v1beta1/:name:setManagement',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "management": {\n    "autoRepair": false,\n    "autoUpgrade": false,\n    "upgradeOptions": {\n      "autoUpgradeStartTime": "",\n      "description": ""\n    }\n  },\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setManagement")
  .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/v1beta1/:name:setManagement',
  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({
  clusterId: '',
  management: {
    autoRepair: false,
    autoUpgrade: false,
    upgradeOptions: {autoUpgradeStartTime: '', description: ''}
  },
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setManagement',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {autoUpgradeStartTime: '', description: ''}
    },
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/:name:setManagement');

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

req.type('json');
req.send({
  clusterId: '',
  management: {
    autoRepair: false,
    autoUpgrade: false,
    upgradeOptions: {
      autoUpgradeStartTime: '',
      description: ''
    }
  },
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:setManagement',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {autoUpgradeStartTime: '', description: ''}
    },
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:name:setManagement';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"name":"","nodePoolId":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"management": @{ @"autoRepair": @NO, @"autoUpgrade": @NO, @"upgradeOptions": @{ @"autoUpgradeStartTime": @"", @"description": @"" } },
                              @"name": @"",
                              @"nodePoolId": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:setManagement"]
                                                       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}}/v1beta1/:name:setManagement" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setManagement",
  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([
    'clusterId' => '',
    'management' => [
        'autoRepair' => null,
        'autoUpgrade' => null,
        'upgradeOptions' => [
                'autoUpgradeStartTime' => '',
                'description' => ''
        ]
    ],
    'name' => '',
    'nodePoolId' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setManagement', [
  'body' => '{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'management' => [
    'autoRepair' => null,
    'autoUpgrade' => null,
    'upgradeOptions' => [
        'autoUpgradeStartTime' => '',
        'description' => ''
    ]
  ],
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'management' => [
    'autoRepair' => null,
    'autoUpgrade' => null,
    'upgradeOptions' => [
        'autoUpgradeStartTime' => '',
        'description' => ''
    ]
  ],
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name:setManagement');
$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}}/v1beta1/:name:setManagement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name:setManagement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
import http.client

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

payload = "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setManagement", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setManagement"

payload = {
    "clusterId": "",
    "management": {
        "autoRepair": False,
        "autoUpgrade": False,
        "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
        }
    },
    "name": "",
    "nodePoolId": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setManagement"

payload <- "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setManagement")

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  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setManagement') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "management": json!({
            "autoRepair": false,
            "autoUpgrade": false,
            "upgradeOptions": json!({
                "autoUpgradeStartTime": "",
                "description": ""
            })
        }),
        "name": "",
        "nodePoolId": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:setManagement \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setManagement \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "management": {\n    "autoRepair": false,\n    "autoUpgrade": false,\n    "upgradeOptions": {\n      "autoUpgradeStartTime": "",\n      "description": ""\n    }\n  },\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setManagement
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "management": [
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": [
      "autoUpgradeStartTime": "",
      "description": ""
    ]
  ],
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setManagement")! 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 container.projects.locations.clusters.nodePools.setSize
{{baseUrl}}/v1beta1/:name:setSize
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setSize" {:content-type :json
                                                                  :form-params {:clusterId ""
                                                                                :name ""
                                                                                :nodeCount 0
                                                                                :nodePoolId ""
                                                                                :projectId ""
                                                                                :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setSize"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setSize"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setSize");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setSize"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setSize HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 106

{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setSize")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setSize"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setSize")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setSize")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  name: '',
  nodeCount: 0,
  nodePoolId: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setSize',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', nodeCount: 0, nodePoolId: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setSize';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","nodeCount":0,"nodePoolId":"","projectId":"","zone":""}'
};

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}}/v1beta1/:name:setSize',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "name": "",\n  "nodeCount": 0,\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setSize")
  .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/v1beta1/:name:setSize',
  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({clusterId: '', name: '', nodeCount: 0, nodePoolId: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setSize',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', name: '', nodeCount: 0, nodePoolId: '', projectId: '', zone: ''},
  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}}/v1beta1/:name:setSize');

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

req.type('json');
req.send({
  clusterId: '',
  name: '',
  nodeCount: 0,
  nodePoolId: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:setSize',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', nodeCount: 0, nodePoolId: '', projectId: '', zone: ''}
};

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

const url = '{{baseUrl}}/v1beta1/:name:setSize';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","nodeCount":0,"nodePoolId":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"name": @"",
                              @"nodeCount": @0,
                              @"nodePoolId": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:setSize"]
                                                       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}}/v1beta1/:name:setSize" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setSize",
  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([
    'clusterId' => '',
    'name' => '',
    'nodeCount' => 0,
    'nodePoolId' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setSize', [
  'body' => '{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'name' => '',
  'nodeCount' => 0,
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'name' => '',
  'nodeCount' => 0,
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name:setSize');
$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}}/v1beta1/:name:setSize' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name:setSize' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
import http.client

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

payload = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setSize", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setSize"

payload = {
    "clusterId": "",
    "name": "",
    "nodeCount": 0,
    "nodePoolId": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setSize"

payload <- "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setSize")

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setSize') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "name": "",
        "nodeCount": 0,
        "nodePoolId": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:setSize \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setSize \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "name": "",\n  "nodeCount": 0,\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setSize
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setSize")! 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 container.projects.locations.clusters.nodePools.update
{{baseUrl}}/v1beta1/:name
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/:name");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}");

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

(client/put "{{baseUrl}}/v1beta1/:name" {:content-type :json
                                                         :form-params {:clusterId ""
                                                                       :confidentialNodes {:enabled false}
                                                                       :etag ""
                                                                       :fastSocket {:enabled false}
                                                                       :gcfsConfig {:enabled false}
                                                                       :gvnic {:enabled false}
                                                                       :imageType ""
                                                                       :kubeletConfig {:cpuCfsQuota false
                                                                                       :cpuCfsQuotaPeriod ""
                                                                                       :cpuManagerPolicy ""
                                                                                       :podPidsLimit ""}
                                                                       :labels {:labels {}}
                                                                       :linuxNodeConfig {:cgroupMode ""
                                                                                         :sysctls {}}
                                                                       :locations []
                                                                       :loggingConfig {:variantConfig {:variant ""}}
                                                                       :name ""
                                                                       :nodeNetworkConfig {:createPodRange false
                                                                                           :enablePrivateNodes false
                                                                                           :networkPerformanceConfig {:externalIpEgressBandwidthTier ""
                                                                                                                      :totalEgressBandwidthTier ""}
                                                                                           :podCidrOverprovisionConfig {:disable false}
                                                                                           :podIpv4CidrBlock ""
                                                                                           :podRange ""}
                                                                       :nodePoolId ""
                                                                       :nodeVersion ""
                                                                       :projectId ""
                                                                       :resourceLabels {:labels {}}
                                                                       :tags {:tags []}
                                                                       :taints {:taints [{:effect ""
                                                                                          :key ""
                                                                                          :value ""}]}
                                                                       :upgradeSettings {:blueGreenSettings {:nodePoolSoakDuration ""
                                                                                                             :standardRolloutPolicy {:batchNodeCount 0
                                                                                                                                     :batchPercentage ""
                                                                                                                                     :batchSoakDuration ""}}
                                                                                         :maxSurge 0
                                                                                         :maxUnavailable 0
                                                                                         :strategy ""}
                                                                       :windowsNodeConfig {:osVersion ""}
                                                                       :workloadMetadataConfig {:mode ""
                                                                                                :nodeMetadata ""}
                                                                       :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/:name"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/:name");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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/v1beta1/:name HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1586

{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/v1beta1/:name")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/v1beta1/:name")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  confidentialNodes: {
    enabled: false
  },
  etag: '',
  fastSocket: {
    enabled: false
  },
  gcfsConfig: {
    enabled: false
  },
  gvnic: {
    enabled: false
  },
  imageType: '',
  kubeletConfig: {
    cpuCfsQuota: false,
    cpuCfsQuotaPeriod: '',
    cpuManagerPolicy: '',
    podPidsLimit: ''
  },
  labels: {
    labels: {}
  },
  linuxNodeConfig: {
    cgroupMode: '',
    sysctls: {}
  },
  locations: [],
  loggingConfig: {
    variantConfig: {
      variant: ''
    }
  },
  name: '',
  nodeNetworkConfig: {
    createPodRange: false,
    enablePrivateNodes: false,
    networkPerformanceConfig: {
      externalIpEgressBandwidthTier: '',
      totalEgressBandwidthTier: ''
    },
    podCidrOverprovisionConfig: {
      disable: false
    },
    podIpv4CidrBlock: '',
    podRange: ''
  },
  nodePoolId: '',
  nodeVersion: '',
  projectId: '',
  resourceLabels: {
    labels: {}
  },
  tags: {
    tags: []
  },
  taints: {
    taints: [
      {
        effect: '',
        key: '',
        value: ''
      }
    ]
  },
  upgradeSettings: {
    blueGreenSettings: {
      nodePoolSoakDuration: '',
      standardRolloutPolicy: {
        batchNodeCount: 0,
        batchPercentage: '',
        batchSoakDuration: ''
      }
    },
    maxSurge: 0,
    maxUnavailable: 0,
    strategy: ''
  },
  windowsNodeConfig: {
    osVersion: ''
  },
  workloadMetadataConfig: {
    mode: '',
    nodeMetadata: ''
  },
  zone: ''
});

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v1beta1/:name',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    confidentialNodes: {enabled: false},
    etag: '',
    fastSocket: {enabled: false},
    gcfsConfig: {enabled: false},
    gvnic: {enabled: false},
    imageType: '',
    kubeletConfig: {
      cpuCfsQuota: false,
      cpuCfsQuotaPeriod: '',
      cpuManagerPolicy: '',
      podPidsLimit: ''
    },
    labels: {labels: {}},
    linuxNodeConfig: {cgroupMode: '', sysctls: {}},
    locations: [],
    loggingConfig: {variantConfig: {variant: ''}},
    name: '',
    nodeNetworkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
      podCidrOverprovisionConfig: {disable: false},
      podIpv4CidrBlock: '',
      podRange: ''
    },
    nodePoolId: '',
    nodeVersion: '',
    projectId: '',
    resourceLabels: {labels: {}},
    tags: {tags: []},
    taints: {taints: [{effect: '', key: '', value: ''}]},
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    windowsNodeConfig: {osVersion: ''},
    workloadMetadataConfig: {mode: '', nodeMetadata: ''},
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","confidentialNodes":{"enabled":false},"etag":"","fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{"labels":{}},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"locations":[],"loggingConfig":{"variantConfig":{"variant":""}},"name":"","nodeNetworkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{"disable":false},"podIpv4CidrBlock":"","podRange":""},"nodePoolId":"","nodeVersion":"","projectId":"","resourceLabels":{"labels":{}},"tags":{"tags":[]},"taints":{"taints":[{"effect":"","key":"","value":""}]},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""},"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""},"zone":""}'
};

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}}/v1beta1/:name',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "confidentialNodes": {\n    "enabled": false\n  },\n  "etag": "",\n  "fastSocket": {\n    "enabled": false\n  },\n  "gcfsConfig": {\n    "enabled": false\n  },\n  "gvnic": {\n    "enabled": false\n  },\n  "imageType": "",\n  "kubeletConfig": {\n    "cpuCfsQuota": false,\n    "cpuCfsQuotaPeriod": "",\n    "cpuManagerPolicy": "",\n    "podPidsLimit": ""\n  },\n  "labels": {\n    "labels": {}\n  },\n  "linuxNodeConfig": {\n    "cgroupMode": "",\n    "sysctls": {}\n  },\n  "locations": [],\n  "loggingConfig": {\n    "variantConfig": {\n      "variant": ""\n    }\n  },\n  "name": "",\n  "nodeNetworkConfig": {\n    "createPodRange": false,\n    "enablePrivateNodes": false,\n    "networkPerformanceConfig": {\n      "externalIpEgressBandwidthTier": "",\n      "totalEgressBandwidthTier": ""\n    },\n    "podCidrOverprovisionConfig": {\n      "disable": false\n    },\n    "podIpv4CidrBlock": "",\n    "podRange": ""\n  },\n  "nodePoolId": "",\n  "nodeVersion": "",\n  "projectId": "",\n  "resourceLabels": {\n    "labels": {}\n  },\n  "tags": {\n    "tags": []\n  },\n  "taints": {\n    "taints": [\n      {\n        "effect": "",\n        "key": "",\n        "value": ""\n      }\n    ]\n  },\n  "upgradeSettings": {\n    "blueGreenSettings": {\n      "nodePoolSoakDuration": "",\n      "standardRolloutPolicy": {\n        "batchNodeCount": 0,\n        "batchPercentage": "",\n        "batchSoakDuration": ""\n      }\n    },\n    "maxSurge": 0,\n    "maxUnavailable": 0,\n    "strategy": ""\n  },\n  "windowsNodeConfig": {\n    "osVersion": ""\n  },\n  "workloadMetadataConfig": {\n    "mode": "",\n    "nodeMetadata": ""\n  },\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name")
  .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/v1beta1/:name',
  headers: {
    'content-type': 'application/json'
  }
};

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

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

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

req.write(JSON.stringify({
  clusterId: '',
  confidentialNodes: {enabled: false},
  etag: '',
  fastSocket: {enabled: false},
  gcfsConfig: {enabled: false},
  gvnic: {enabled: false},
  imageType: '',
  kubeletConfig: {
    cpuCfsQuota: false,
    cpuCfsQuotaPeriod: '',
    cpuManagerPolicy: '',
    podPidsLimit: ''
  },
  labels: {labels: {}},
  linuxNodeConfig: {cgroupMode: '', sysctls: {}},
  locations: [],
  loggingConfig: {variantConfig: {variant: ''}},
  name: '',
  nodeNetworkConfig: {
    createPodRange: false,
    enablePrivateNodes: false,
    networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
    podCidrOverprovisionConfig: {disable: false},
    podIpv4CidrBlock: '',
    podRange: ''
  },
  nodePoolId: '',
  nodeVersion: '',
  projectId: '',
  resourceLabels: {labels: {}},
  tags: {tags: []},
  taints: {taints: [{effect: '', key: '', value: ''}]},
  upgradeSettings: {
    blueGreenSettings: {
      nodePoolSoakDuration: '',
      standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
    },
    maxSurge: 0,
    maxUnavailable: 0,
    strategy: ''
  },
  windowsNodeConfig: {osVersion: ''},
  workloadMetadataConfig: {mode: '', nodeMetadata: ''},
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v1beta1/:name',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    confidentialNodes: {enabled: false},
    etag: '',
    fastSocket: {enabled: false},
    gcfsConfig: {enabled: false},
    gvnic: {enabled: false},
    imageType: '',
    kubeletConfig: {
      cpuCfsQuota: false,
      cpuCfsQuotaPeriod: '',
      cpuManagerPolicy: '',
      podPidsLimit: ''
    },
    labels: {labels: {}},
    linuxNodeConfig: {cgroupMode: '', sysctls: {}},
    locations: [],
    loggingConfig: {variantConfig: {variant: ''}},
    name: '',
    nodeNetworkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
      podCidrOverprovisionConfig: {disable: false},
      podIpv4CidrBlock: '',
      podRange: ''
    },
    nodePoolId: '',
    nodeVersion: '',
    projectId: '',
    resourceLabels: {labels: {}},
    tags: {tags: []},
    taints: {taints: [{effect: '', key: '', value: ''}]},
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    windowsNodeConfig: {osVersion: ''},
    workloadMetadataConfig: {mode: '', nodeMetadata: ''},
    zone: ''
  },
  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}}/v1beta1/:name');

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

req.type('json');
req.send({
  clusterId: '',
  confidentialNodes: {
    enabled: false
  },
  etag: '',
  fastSocket: {
    enabled: false
  },
  gcfsConfig: {
    enabled: false
  },
  gvnic: {
    enabled: false
  },
  imageType: '',
  kubeletConfig: {
    cpuCfsQuota: false,
    cpuCfsQuotaPeriod: '',
    cpuManagerPolicy: '',
    podPidsLimit: ''
  },
  labels: {
    labels: {}
  },
  linuxNodeConfig: {
    cgroupMode: '',
    sysctls: {}
  },
  locations: [],
  loggingConfig: {
    variantConfig: {
      variant: ''
    }
  },
  name: '',
  nodeNetworkConfig: {
    createPodRange: false,
    enablePrivateNodes: false,
    networkPerformanceConfig: {
      externalIpEgressBandwidthTier: '',
      totalEgressBandwidthTier: ''
    },
    podCidrOverprovisionConfig: {
      disable: false
    },
    podIpv4CidrBlock: '',
    podRange: ''
  },
  nodePoolId: '',
  nodeVersion: '',
  projectId: '',
  resourceLabels: {
    labels: {}
  },
  tags: {
    tags: []
  },
  taints: {
    taints: [
      {
        effect: '',
        key: '',
        value: ''
      }
    ]
  },
  upgradeSettings: {
    blueGreenSettings: {
      nodePoolSoakDuration: '',
      standardRolloutPolicy: {
        batchNodeCount: 0,
        batchPercentage: '',
        batchSoakDuration: ''
      }
    },
    maxSurge: 0,
    maxUnavailable: 0,
    strategy: ''
  },
  windowsNodeConfig: {
    osVersion: ''
  },
  workloadMetadataConfig: {
    mode: '',
    nodeMetadata: ''
  },
  zone: ''
});

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}}/v1beta1/:name',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    confidentialNodes: {enabled: false},
    etag: '',
    fastSocket: {enabled: false},
    gcfsConfig: {enabled: false},
    gvnic: {enabled: false},
    imageType: '',
    kubeletConfig: {
      cpuCfsQuota: false,
      cpuCfsQuotaPeriod: '',
      cpuManagerPolicy: '',
      podPidsLimit: ''
    },
    labels: {labels: {}},
    linuxNodeConfig: {cgroupMode: '', sysctls: {}},
    locations: [],
    loggingConfig: {variantConfig: {variant: ''}},
    name: '',
    nodeNetworkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
      podCidrOverprovisionConfig: {disable: false},
      podIpv4CidrBlock: '',
      podRange: ''
    },
    nodePoolId: '',
    nodeVersion: '',
    projectId: '',
    resourceLabels: {labels: {}},
    tags: {tags: []},
    taints: {taints: [{effect: '', key: '', value: ''}]},
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    windowsNodeConfig: {osVersion: ''},
    workloadMetadataConfig: {mode: '', nodeMetadata: ''},
    zone: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:name';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","confidentialNodes":{"enabled":false},"etag":"","fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{"labels":{}},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"locations":[],"loggingConfig":{"variantConfig":{"variant":""}},"name":"","nodeNetworkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{"disable":false},"podIpv4CidrBlock":"","podRange":""},"nodePoolId":"","nodeVersion":"","projectId":"","resourceLabels":{"labels":{}},"tags":{"tags":[]},"taints":{"taints":[{"effect":"","key":"","value":""}]},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""},"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""},"zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"confidentialNodes": @{ @"enabled": @NO },
                              @"etag": @"",
                              @"fastSocket": @{ @"enabled": @NO },
                              @"gcfsConfig": @{ @"enabled": @NO },
                              @"gvnic": @{ @"enabled": @NO },
                              @"imageType": @"",
                              @"kubeletConfig": @{ @"cpuCfsQuota": @NO, @"cpuCfsQuotaPeriod": @"", @"cpuManagerPolicy": @"", @"podPidsLimit": @"" },
                              @"labels": @{ @"labels": @{  } },
                              @"linuxNodeConfig": @{ @"cgroupMode": @"", @"sysctls": @{  } },
                              @"locations": @[  ],
                              @"loggingConfig": @{ @"variantConfig": @{ @"variant": @"" } },
                              @"name": @"",
                              @"nodeNetworkConfig": @{ @"createPodRange": @NO, @"enablePrivateNodes": @NO, @"networkPerformanceConfig": @{ @"externalIpEgressBandwidthTier": @"", @"totalEgressBandwidthTier": @"" }, @"podCidrOverprovisionConfig": @{ @"disable": @NO }, @"podIpv4CidrBlock": @"", @"podRange": @"" },
                              @"nodePoolId": @"",
                              @"nodeVersion": @"",
                              @"projectId": @"",
                              @"resourceLabels": @{ @"labels": @{  } },
                              @"tags": @{ @"tags": @[  ] },
                              @"taints": @{ @"taints": @[ @{ @"effect": @"", @"key": @"", @"value": @"" } ] },
                              @"upgradeSettings": @{ @"blueGreenSettings": @{ @"nodePoolSoakDuration": @"", @"standardRolloutPolicy": @{ @"batchNodeCount": @0, @"batchPercentage": @"", @"batchSoakDuration": @"" } }, @"maxSurge": @0, @"maxUnavailable": @0, @"strategy": @"" },
                              @"windowsNodeConfig": @{ @"osVersion": @"" },
                              @"workloadMetadataConfig": @{ @"mode": @"", @"nodeMetadata": @"" },
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name"]
                                                       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}}/v1beta1/:name" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name",
  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([
    'clusterId' => '',
    'confidentialNodes' => [
        'enabled' => null
    ],
    'etag' => '',
    'fastSocket' => [
        'enabled' => null
    ],
    'gcfsConfig' => [
        'enabled' => null
    ],
    'gvnic' => [
        'enabled' => null
    ],
    'imageType' => '',
    'kubeletConfig' => [
        'cpuCfsQuota' => null,
        'cpuCfsQuotaPeriod' => '',
        'cpuManagerPolicy' => '',
        'podPidsLimit' => ''
    ],
    'labels' => [
        'labels' => [
                
        ]
    ],
    'linuxNodeConfig' => [
        'cgroupMode' => '',
        'sysctls' => [
                
        ]
    ],
    'locations' => [
        
    ],
    'loggingConfig' => [
        'variantConfig' => [
                'variant' => ''
        ]
    ],
    'name' => '',
    'nodeNetworkConfig' => [
        'createPodRange' => null,
        'enablePrivateNodes' => null,
        'networkPerformanceConfig' => [
                'externalIpEgressBandwidthTier' => '',
                'totalEgressBandwidthTier' => ''
        ],
        'podCidrOverprovisionConfig' => [
                'disable' => null
        ],
        'podIpv4CidrBlock' => '',
        'podRange' => ''
    ],
    'nodePoolId' => '',
    'nodeVersion' => '',
    'projectId' => '',
    'resourceLabels' => [
        'labels' => [
                
        ]
    ],
    'tags' => [
        'tags' => [
                
        ]
    ],
    'taints' => [
        'taints' => [
                [
                                'effect' => '',
                                'key' => '',
                                'value' => ''
                ]
        ]
    ],
    'upgradeSettings' => [
        'blueGreenSettings' => [
                'nodePoolSoakDuration' => '',
                'standardRolloutPolicy' => [
                                'batchNodeCount' => 0,
                                'batchPercentage' => '',
                                'batchSoakDuration' => ''
                ]
        ],
        'maxSurge' => 0,
        'maxUnavailable' => 0,
        'strategy' => ''
    ],
    'windowsNodeConfig' => [
        'osVersion' => ''
    ],
    'workloadMetadataConfig' => [
        'mode' => '',
        'nodeMetadata' => ''
    ],
    'zone' => ''
  ]),
  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}}/v1beta1/:name', [
  'body' => '{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'confidentialNodes' => [
    'enabled' => null
  ],
  'etag' => '',
  'fastSocket' => [
    'enabled' => null
  ],
  'gcfsConfig' => [
    'enabled' => null
  ],
  'gvnic' => [
    'enabled' => null
  ],
  'imageType' => '',
  'kubeletConfig' => [
    'cpuCfsQuota' => null,
    'cpuCfsQuotaPeriod' => '',
    'cpuManagerPolicy' => '',
    'podPidsLimit' => ''
  ],
  'labels' => [
    'labels' => [
        
    ]
  ],
  'linuxNodeConfig' => [
    'cgroupMode' => '',
    'sysctls' => [
        
    ]
  ],
  'locations' => [
    
  ],
  'loggingConfig' => [
    'variantConfig' => [
        'variant' => ''
    ]
  ],
  'name' => '',
  'nodeNetworkConfig' => [
    'createPodRange' => null,
    'enablePrivateNodes' => null,
    'networkPerformanceConfig' => [
        'externalIpEgressBandwidthTier' => '',
        'totalEgressBandwidthTier' => ''
    ],
    'podCidrOverprovisionConfig' => [
        'disable' => null
    ],
    'podIpv4CidrBlock' => '',
    'podRange' => ''
  ],
  'nodePoolId' => '',
  'nodeVersion' => '',
  'projectId' => '',
  'resourceLabels' => [
    'labels' => [
        
    ]
  ],
  'tags' => [
    'tags' => [
        
    ]
  ],
  'taints' => [
    'taints' => [
        [
                'effect' => '',
                'key' => '',
                'value' => ''
        ]
    ]
  ],
  'upgradeSettings' => [
    'blueGreenSettings' => [
        'nodePoolSoakDuration' => '',
        'standardRolloutPolicy' => [
                'batchNodeCount' => 0,
                'batchPercentage' => '',
                'batchSoakDuration' => ''
        ]
    ],
    'maxSurge' => 0,
    'maxUnavailable' => 0,
    'strategy' => ''
  ],
  'windowsNodeConfig' => [
    'osVersion' => ''
  ],
  'workloadMetadataConfig' => [
    'mode' => '',
    'nodeMetadata' => ''
  ],
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'confidentialNodes' => [
    'enabled' => null
  ],
  'etag' => '',
  'fastSocket' => [
    'enabled' => null
  ],
  'gcfsConfig' => [
    'enabled' => null
  ],
  'gvnic' => [
    'enabled' => null
  ],
  'imageType' => '',
  'kubeletConfig' => [
    'cpuCfsQuota' => null,
    'cpuCfsQuotaPeriod' => '',
    'cpuManagerPolicy' => '',
    'podPidsLimit' => ''
  ],
  'labels' => [
    'labels' => [
        
    ]
  ],
  'linuxNodeConfig' => [
    'cgroupMode' => '',
    'sysctls' => [
        
    ]
  ],
  'locations' => [
    
  ],
  'loggingConfig' => [
    'variantConfig' => [
        'variant' => ''
    ]
  ],
  'name' => '',
  'nodeNetworkConfig' => [
    'createPodRange' => null,
    'enablePrivateNodes' => null,
    'networkPerformanceConfig' => [
        'externalIpEgressBandwidthTier' => '',
        'totalEgressBandwidthTier' => ''
    ],
    'podCidrOverprovisionConfig' => [
        'disable' => null
    ],
    'podIpv4CidrBlock' => '',
    'podRange' => ''
  ],
  'nodePoolId' => '',
  'nodeVersion' => '',
  'projectId' => '',
  'resourceLabels' => [
    'labels' => [
        
    ]
  ],
  'tags' => [
    'tags' => [
        
    ]
  ],
  'taints' => [
    'taints' => [
        [
                'effect' => '',
                'key' => '',
                'value' => ''
        ]
    ]
  ],
  'upgradeSettings' => [
    'blueGreenSettings' => [
        'nodePoolSoakDuration' => '',
        'standardRolloutPolicy' => [
                'batchNodeCount' => 0,
                'batchPercentage' => '',
                'batchSoakDuration' => ''
        ]
    ],
    'maxSurge' => 0,
    'maxUnavailable' => 0,
    'strategy' => ''
  ],
  'windowsNodeConfig' => [
    'osVersion' => ''
  ],
  'workloadMetadataConfig' => [
    'mode' => '',
    'nodeMetadata' => ''
  ],
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name');
$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}}/v1beta1/:name' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}'
import http.client

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

payload = "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}"

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

conn.request("PUT", "/baseUrl/v1beta1/:name", payload, headers)

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

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

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

payload = {
    "clusterId": "",
    "confidentialNodes": { "enabled": False },
    "etag": "",
    "fastSocket": { "enabled": False },
    "gcfsConfig": { "enabled": False },
    "gvnic": { "enabled": False },
    "imageType": "",
    "kubeletConfig": {
        "cpuCfsQuota": False,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
    },
    "labels": { "labels": {} },
    "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
    },
    "locations": [],
    "loggingConfig": { "variantConfig": { "variant": "" } },
    "name": "",
    "nodeNetworkConfig": {
        "createPodRange": False,
        "enablePrivateNodes": False,
        "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
        },
        "podCidrOverprovisionConfig": { "disable": False },
        "podIpv4CidrBlock": "",
        "podRange": ""
    },
    "nodePoolId": "",
    "nodeVersion": "",
    "projectId": "",
    "resourceLabels": { "labels": {} },
    "tags": { "tags": [] },
    "taints": { "taints": [
            {
                "effect": "",
                "key": "",
                "value": ""
            }
        ] },
    "upgradeSettings": {
        "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
                "batchNodeCount": 0,
                "batchPercentage": "",
                "batchSoakDuration": ""
            }
        },
        "maxSurge": 0,
        "maxUnavailable": 0,
        "strategy": ""
    },
    "windowsNodeConfig": { "osVersion": "" },
    "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
    },
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/:name")

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  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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/v1beta1/:name') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/:name";

    let payload = json!({
        "clusterId": "",
        "confidentialNodes": json!({"enabled": false}),
        "etag": "",
        "fastSocket": json!({"enabled": false}),
        "gcfsConfig": json!({"enabled": false}),
        "gvnic": json!({"enabled": false}),
        "imageType": "",
        "kubeletConfig": json!({
            "cpuCfsQuota": false,
            "cpuCfsQuotaPeriod": "",
            "cpuManagerPolicy": "",
            "podPidsLimit": ""
        }),
        "labels": json!({"labels": json!({})}),
        "linuxNodeConfig": json!({
            "cgroupMode": "",
            "sysctls": json!({})
        }),
        "locations": (),
        "loggingConfig": json!({"variantConfig": json!({"variant": ""})}),
        "name": "",
        "nodeNetworkConfig": json!({
            "createPodRange": false,
            "enablePrivateNodes": false,
            "networkPerformanceConfig": json!({
                "externalIpEgressBandwidthTier": "",
                "totalEgressBandwidthTier": ""
            }),
            "podCidrOverprovisionConfig": json!({"disable": false}),
            "podIpv4CidrBlock": "",
            "podRange": ""
        }),
        "nodePoolId": "",
        "nodeVersion": "",
        "projectId": "",
        "resourceLabels": json!({"labels": json!({})}),
        "tags": json!({"tags": ()}),
        "taints": json!({"taints": (
                json!({
                    "effect": "",
                    "key": "",
                    "value": ""
                })
            )}),
        "upgradeSettings": json!({
            "blueGreenSettings": json!({
                "nodePoolSoakDuration": "",
                "standardRolloutPolicy": json!({
                    "batchNodeCount": 0,
                    "batchPercentage": "",
                    "batchSoakDuration": ""
                })
            }),
            "maxSurge": 0,
            "maxUnavailable": 0,
            "strategy": ""
        }),
        "windowsNodeConfig": json!({"osVersion": ""}),
        "workloadMetadataConfig": json!({
            "mode": "",
            "nodeMetadata": ""
        }),
        "zone": ""
    });

    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}}/v1beta1/:name \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}'
echo '{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}' |  \
  http PUT {{baseUrl}}/v1beta1/:name \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "confidentialNodes": {\n    "enabled": false\n  },\n  "etag": "",\n  "fastSocket": {\n    "enabled": false\n  },\n  "gcfsConfig": {\n    "enabled": false\n  },\n  "gvnic": {\n    "enabled": false\n  },\n  "imageType": "",\n  "kubeletConfig": {\n    "cpuCfsQuota": false,\n    "cpuCfsQuotaPeriod": "",\n    "cpuManagerPolicy": "",\n    "podPidsLimit": ""\n  },\n  "labels": {\n    "labels": {}\n  },\n  "linuxNodeConfig": {\n    "cgroupMode": "",\n    "sysctls": {}\n  },\n  "locations": [],\n  "loggingConfig": {\n    "variantConfig": {\n      "variant": ""\n    }\n  },\n  "name": "",\n  "nodeNetworkConfig": {\n    "createPodRange": false,\n    "enablePrivateNodes": false,\n    "networkPerformanceConfig": {\n      "externalIpEgressBandwidthTier": "",\n      "totalEgressBandwidthTier": ""\n    },\n    "podCidrOverprovisionConfig": {\n      "disable": false\n    },\n    "podIpv4CidrBlock": "",\n    "podRange": ""\n  },\n  "nodePoolId": "",\n  "nodeVersion": "",\n  "projectId": "",\n  "resourceLabels": {\n    "labels": {}\n  },\n  "tags": {\n    "tags": []\n  },\n  "taints": {\n    "taints": [\n      {\n        "effect": "",\n        "key": "",\n        "value": ""\n      }\n    ]\n  },\n  "upgradeSettings": {\n    "blueGreenSettings": {\n      "nodePoolSoakDuration": "",\n      "standardRolloutPolicy": {\n        "batchNodeCount": 0,\n        "batchPercentage": "",\n        "batchSoakDuration": ""\n      }\n    },\n    "maxSurge": 0,\n    "maxUnavailable": 0,\n    "strategy": ""\n  },\n  "windowsNodeConfig": {\n    "osVersion": ""\n  },\n  "workloadMetadataConfig": {\n    "mode": "",\n    "nodeMetadata": ""\n  },\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "confidentialNodes": ["enabled": false],
  "etag": "",
  "fastSocket": ["enabled": false],
  "gcfsConfig": ["enabled": false],
  "gvnic": ["enabled": false],
  "imageType": "",
  "kubeletConfig": [
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  ],
  "labels": ["labels": []],
  "linuxNodeConfig": [
    "cgroupMode": "",
    "sysctls": []
  ],
  "locations": [],
  "loggingConfig": ["variantConfig": ["variant": ""]],
  "name": "",
  "nodeNetworkConfig": [
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": [
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    ],
    "podCidrOverprovisionConfig": ["disable": false],
    "podIpv4CidrBlock": "",
    "podRange": ""
  ],
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": ["labels": []],
  "tags": ["tags": []],
  "taints": ["taints": [
      [
        "effect": "",
        "key": "",
        "value": ""
      ]
    ]],
  "upgradeSettings": [
    "blueGreenSettings": [
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": [
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      ]
    ],
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  ],
  "windowsNodeConfig": ["osVersion": ""],
  "workloadMetadataConfig": [
    "mode": "",
    "nodeMetadata": ""
  ],
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name")! 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 container.projects.locations.clusters.setAddons
{{baseUrl}}/v1beta1/:name:setAddons
QUERY PARAMS

name
BODY json

{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setAddons" {:content-type :json
                                                                    :form-params {:addonsConfig {:cloudRunConfig {:disabled false
                                                                                                                  :loadBalancerType ""}
                                                                                                 :configConnectorConfig {:enabled false}
                                                                                                 :dnsCacheConfig {:enabled false}
                                                                                                 :gcePersistentDiskCsiDriverConfig {:enabled false}
                                                                                                 :gcpFilestoreCsiDriverConfig {:enabled false}
                                                                                                 :gkeBackupAgentConfig {:enabled false}
                                                                                                 :horizontalPodAutoscaling {:disabled false}
                                                                                                 :httpLoadBalancing {:disabled false}
                                                                                                 :istioConfig {:auth ""
                                                                                                               :disabled false}
                                                                                                 :kalmConfig {:enabled false}
                                                                                                 :kubernetesDashboard {:disabled false}
                                                                                                 :networkPolicyConfig {:disabled false}}
                                                                                  :clusterId ""
                                                                                  :name ""
                                                                                  :projectId ""
                                                                                  :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setAddons"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setAddons"),
    Content = new StringContent("{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setAddons");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setAddons"

	payload := strings.NewReader("{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setAddons HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 854

{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setAddons")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setAddons"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setAddons")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setAddons")
  .header("content-type", "application/json")
  .body("{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  addonsConfig: {
    cloudRunConfig: {
      disabled: false,
      loadBalancerType: ''
    },
    configConnectorConfig: {
      enabled: false
    },
    dnsCacheConfig: {
      enabled: false
    },
    gcePersistentDiskCsiDriverConfig: {
      enabled: false
    },
    gcpFilestoreCsiDriverConfig: {
      enabled: false
    },
    gkeBackupAgentConfig: {
      enabled: false
    },
    horizontalPodAutoscaling: {
      disabled: false
    },
    httpLoadBalancing: {
      disabled: false
    },
    istioConfig: {
      auth: '',
      disabled: false
    },
    kalmConfig: {
      enabled: false
    },
    kubernetesDashboard: {
      disabled: false
    },
    networkPolicyConfig: {
      disabled: false
    }
  },
  clusterId: '',
  name: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setAddons',
  headers: {'content-type': 'application/json'},
  data: {
    addonsConfig: {
      cloudRunConfig: {disabled: false, loadBalancerType: ''},
      configConnectorConfig: {enabled: false},
      dnsCacheConfig: {enabled: false},
      gcePersistentDiskCsiDriverConfig: {enabled: false},
      gcpFilestoreCsiDriverConfig: {enabled: false},
      gkeBackupAgentConfig: {enabled: false},
      horizontalPodAutoscaling: {disabled: false},
      httpLoadBalancing: {disabled: false},
      istioConfig: {auth: '', disabled: false},
      kalmConfig: {enabled: false},
      kubernetesDashboard: {disabled: false},
      networkPolicyConfig: {disabled: false}
    },
    clusterId: '',
    name: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setAddons';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addonsConfig":{"cloudRunConfig":{"disabled":false,"loadBalancerType":""},"configConnectorConfig":{"enabled":false},"dnsCacheConfig":{"enabled":false},"gcePersistentDiskCsiDriverConfig":{"enabled":false},"gcpFilestoreCsiDriverConfig":{"enabled":false},"gkeBackupAgentConfig":{"enabled":false},"horizontalPodAutoscaling":{"disabled":false},"httpLoadBalancing":{"disabled":false},"istioConfig":{"auth":"","disabled":false},"kalmConfig":{"enabled":false},"kubernetesDashboard":{"disabled":false},"networkPolicyConfig":{"disabled":false}},"clusterId":"","name":"","projectId":"","zone":""}'
};

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}}/v1beta1/:name:setAddons',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addonsConfig": {\n    "cloudRunConfig": {\n      "disabled": false,\n      "loadBalancerType": ""\n    },\n    "configConnectorConfig": {\n      "enabled": false\n    },\n    "dnsCacheConfig": {\n      "enabled": false\n    },\n    "gcePersistentDiskCsiDriverConfig": {\n      "enabled": false\n    },\n    "gcpFilestoreCsiDriverConfig": {\n      "enabled": false\n    },\n    "gkeBackupAgentConfig": {\n      "enabled": false\n    },\n    "horizontalPodAutoscaling": {\n      "disabled": false\n    },\n    "httpLoadBalancing": {\n      "disabled": false\n    },\n    "istioConfig": {\n      "auth": "",\n      "disabled": false\n    },\n    "kalmConfig": {\n      "enabled": false\n    },\n    "kubernetesDashboard": {\n      "disabled": false\n    },\n    "networkPolicyConfig": {\n      "disabled": false\n    }\n  },\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setAddons")
  .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/v1beta1/:name:setAddons',
  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({
  addonsConfig: {
    cloudRunConfig: {disabled: false, loadBalancerType: ''},
    configConnectorConfig: {enabled: false},
    dnsCacheConfig: {enabled: false},
    gcePersistentDiskCsiDriverConfig: {enabled: false},
    gcpFilestoreCsiDriverConfig: {enabled: false},
    gkeBackupAgentConfig: {enabled: false},
    horizontalPodAutoscaling: {disabled: false},
    httpLoadBalancing: {disabled: false},
    istioConfig: {auth: '', disabled: false},
    kalmConfig: {enabled: false},
    kubernetesDashboard: {disabled: false},
    networkPolicyConfig: {disabled: false}
  },
  clusterId: '',
  name: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setAddons',
  headers: {'content-type': 'application/json'},
  body: {
    addonsConfig: {
      cloudRunConfig: {disabled: false, loadBalancerType: ''},
      configConnectorConfig: {enabled: false},
      dnsCacheConfig: {enabled: false},
      gcePersistentDiskCsiDriverConfig: {enabled: false},
      gcpFilestoreCsiDriverConfig: {enabled: false},
      gkeBackupAgentConfig: {enabled: false},
      horizontalPodAutoscaling: {disabled: false},
      httpLoadBalancing: {disabled: false},
      istioConfig: {auth: '', disabled: false},
      kalmConfig: {enabled: false},
      kubernetesDashboard: {disabled: false},
      networkPolicyConfig: {disabled: false}
    },
    clusterId: '',
    name: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/:name:setAddons');

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

req.type('json');
req.send({
  addonsConfig: {
    cloudRunConfig: {
      disabled: false,
      loadBalancerType: ''
    },
    configConnectorConfig: {
      enabled: false
    },
    dnsCacheConfig: {
      enabled: false
    },
    gcePersistentDiskCsiDriverConfig: {
      enabled: false
    },
    gcpFilestoreCsiDriverConfig: {
      enabled: false
    },
    gkeBackupAgentConfig: {
      enabled: false
    },
    horizontalPodAutoscaling: {
      disabled: false
    },
    httpLoadBalancing: {
      disabled: false
    },
    istioConfig: {
      auth: '',
      disabled: false
    },
    kalmConfig: {
      enabled: false
    },
    kubernetesDashboard: {
      disabled: false
    },
    networkPolicyConfig: {
      disabled: false
    }
  },
  clusterId: '',
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:setAddons',
  headers: {'content-type': 'application/json'},
  data: {
    addonsConfig: {
      cloudRunConfig: {disabled: false, loadBalancerType: ''},
      configConnectorConfig: {enabled: false},
      dnsCacheConfig: {enabled: false},
      gcePersistentDiskCsiDriverConfig: {enabled: false},
      gcpFilestoreCsiDriverConfig: {enabled: false},
      gkeBackupAgentConfig: {enabled: false},
      horizontalPodAutoscaling: {disabled: false},
      httpLoadBalancing: {disabled: false},
      istioConfig: {auth: '', disabled: false},
      kalmConfig: {enabled: false},
      kubernetesDashboard: {disabled: false},
      networkPolicyConfig: {disabled: false}
    },
    clusterId: '',
    name: '',
    projectId: '',
    zone: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:name:setAddons';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addonsConfig":{"cloudRunConfig":{"disabled":false,"loadBalancerType":""},"configConnectorConfig":{"enabled":false},"dnsCacheConfig":{"enabled":false},"gcePersistentDiskCsiDriverConfig":{"enabled":false},"gcpFilestoreCsiDriverConfig":{"enabled":false},"gkeBackupAgentConfig":{"enabled":false},"horizontalPodAutoscaling":{"disabled":false},"httpLoadBalancing":{"disabled":false},"istioConfig":{"auth":"","disabled":false},"kalmConfig":{"enabled":false},"kubernetesDashboard":{"disabled":false},"networkPolicyConfig":{"disabled":false}},"clusterId":"","name":"","projectId":"","zone":""}'
};

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 = @{ @"addonsConfig": @{ @"cloudRunConfig": @{ @"disabled": @NO, @"loadBalancerType": @"" }, @"configConnectorConfig": @{ @"enabled": @NO }, @"dnsCacheConfig": @{ @"enabled": @NO }, @"gcePersistentDiskCsiDriverConfig": @{ @"enabled": @NO }, @"gcpFilestoreCsiDriverConfig": @{ @"enabled": @NO }, @"gkeBackupAgentConfig": @{ @"enabled": @NO }, @"horizontalPodAutoscaling": @{ @"disabled": @NO }, @"httpLoadBalancing": @{ @"disabled": @NO }, @"istioConfig": @{ @"auth": @"", @"disabled": @NO }, @"kalmConfig": @{ @"enabled": @NO }, @"kubernetesDashboard": @{ @"disabled": @NO }, @"networkPolicyConfig": @{ @"disabled": @NO } },
                              @"clusterId": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:setAddons"]
                                                       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}}/v1beta1/:name:setAddons" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setAddons",
  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([
    'addonsConfig' => [
        'cloudRunConfig' => [
                'disabled' => null,
                'loadBalancerType' => ''
        ],
        'configConnectorConfig' => [
                'enabled' => null
        ],
        'dnsCacheConfig' => [
                'enabled' => null
        ],
        'gcePersistentDiskCsiDriverConfig' => [
                'enabled' => null
        ],
        'gcpFilestoreCsiDriverConfig' => [
                'enabled' => null
        ],
        'gkeBackupAgentConfig' => [
                'enabled' => null
        ],
        'horizontalPodAutoscaling' => [
                'disabled' => null
        ],
        'httpLoadBalancing' => [
                'disabled' => null
        ],
        'istioConfig' => [
                'auth' => '',
                'disabled' => null
        ],
        'kalmConfig' => [
                'enabled' => null
        ],
        'kubernetesDashboard' => [
                'disabled' => null
        ],
        'networkPolicyConfig' => [
                'disabled' => null
        ]
    ],
    'clusterId' => '',
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setAddons', [
  'body' => '{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addonsConfig' => [
    'cloudRunConfig' => [
        'disabled' => null,
        'loadBalancerType' => ''
    ],
    'configConnectorConfig' => [
        'enabled' => null
    ],
    'dnsCacheConfig' => [
        'enabled' => null
    ],
    'gcePersistentDiskCsiDriverConfig' => [
        'enabled' => null
    ],
    'gcpFilestoreCsiDriverConfig' => [
        'enabled' => null
    ],
    'gkeBackupAgentConfig' => [
        'enabled' => null
    ],
    'horizontalPodAutoscaling' => [
        'disabled' => null
    ],
    'httpLoadBalancing' => [
        'disabled' => null
    ],
    'istioConfig' => [
        'auth' => '',
        'disabled' => null
    ],
    'kalmConfig' => [
        'enabled' => null
    ],
    'kubernetesDashboard' => [
        'disabled' => null
    ],
    'networkPolicyConfig' => [
        'disabled' => null
    ]
  ],
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addonsConfig' => [
    'cloudRunConfig' => [
        'disabled' => null,
        'loadBalancerType' => ''
    ],
    'configConnectorConfig' => [
        'enabled' => null
    ],
    'dnsCacheConfig' => [
        'enabled' => null
    ],
    'gcePersistentDiskCsiDriverConfig' => [
        'enabled' => null
    ],
    'gcpFilestoreCsiDriverConfig' => [
        'enabled' => null
    ],
    'gkeBackupAgentConfig' => [
        'enabled' => null
    ],
    'horizontalPodAutoscaling' => [
        'disabled' => null
    ],
    'httpLoadBalancing' => [
        'disabled' => null
    ],
    'istioConfig' => [
        'auth' => '',
        'disabled' => null
    ],
    'kalmConfig' => [
        'enabled' => null
    ],
    'kubernetesDashboard' => [
        'disabled' => null
    ],
    'networkPolicyConfig' => [
        'disabled' => null
    ]
  ],
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name:setAddons');
$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}}/v1beta1/:name:setAddons' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name:setAddons' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
import http.client

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

payload = "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setAddons", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setAddons"

payload = {
    "addonsConfig": {
        "cloudRunConfig": {
            "disabled": False,
            "loadBalancerType": ""
        },
        "configConnectorConfig": { "enabled": False },
        "dnsCacheConfig": { "enabled": False },
        "gcePersistentDiskCsiDriverConfig": { "enabled": False },
        "gcpFilestoreCsiDriverConfig": { "enabled": False },
        "gkeBackupAgentConfig": { "enabled": False },
        "horizontalPodAutoscaling": { "disabled": False },
        "httpLoadBalancing": { "disabled": False },
        "istioConfig": {
            "auth": "",
            "disabled": False
        },
        "kalmConfig": { "enabled": False },
        "kubernetesDashboard": { "disabled": False },
        "networkPolicyConfig": { "disabled": False }
    },
    "clusterId": "",
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setAddons"

payload <- "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setAddons")

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  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setAddons') do |req|
  req.body = "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "addonsConfig": json!({
            "cloudRunConfig": json!({
                "disabled": false,
                "loadBalancerType": ""
            }),
            "configConnectorConfig": json!({"enabled": false}),
            "dnsCacheConfig": json!({"enabled": false}),
            "gcePersistentDiskCsiDriverConfig": json!({"enabled": false}),
            "gcpFilestoreCsiDriverConfig": json!({"enabled": false}),
            "gkeBackupAgentConfig": json!({"enabled": false}),
            "horizontalPodAutoscaling": json!({"disabled": false}),
            "httpLoadBalancing": json!({"disabled": false}),
            "istioConfig": json!({
                "auth": "",
                "disabled": false
            }),
            "kalmConfig": json!({"enabled": false}),
            "kubernetesDashboard": json!({"disabled": false}),
            "networkPolicyConfig": json!({"disabled": false})
        }),
        "clusterId": "",
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:setAddons \
  --header 'content-type: application/json' \
  --data '{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setAddons \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addonsConfig": {\n    "cloudRunConfig": {\n      "disabled": false,\n      "loadBalancerType": ""\n    },\n    "configConnectorConfig": {\n      "enabled": false\n    },\n    "dnsCacheConfig": {\n      "enabled": false\n    },\n    "gcePersistentDiskCsiDriverConfig": {\n      "enabled": false\n    },\n    "gcpFilestoreCsiDriverConfig": {\n      "enabled": false\n    },\n    "gkeBackupAgentConfig": {\n      "enabled": false\n    },\n    "horizontalPodAutoscaling": {\n      "disabled": false\n    },\n    "httpLoadBalancing": {\n      "disabled": false\n    },\n    "istioConfig": {\n      "auth": "",\n      "disabled": false\n    },\n    "kalmConfig": {\n      "enabled": false\n    },\n    "kubernetesDashboard": {\n      "disabled": false\n    },\n    "networkPolicyConfig": {\n      "disabled": false\n    }\n  },\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setAddons
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "addonsConfig": [
    "cloudRunConfig": [
      "disabled": false,
      "loadBalancerType": ""
    ],
    "configConnectorConfig": ["enabled": false],
    "dnsCacheConfig": ["enabled": false],
    "gcePersistentDiskCsiDriverConfig": ["enabled": false],
    "gcpFilestoreCsiDriverConfig": ["enabled": false],
    "gkeBackupAgentConfig": ["enabled": false],
    "horizontalPodAutoscaling": ["disabled": false],
    "httpLoadBalancing": ["disabled": false],
    "istioConfig": [
      "auth": "",
      "disabled": false
    ],
    "kalmConfig": ["enabled": false],
    "kubernetesDashboard": ["disabled": false],
    "networkPolicyConfig": ["disabled": false]
  ],
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setAddons")! 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 container.projects.locations.clusters.setLegacyAbac
{{baseUrl}}/v1beta1/:name:setLegacyAbac
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setLegacyAbac" {:content-type :json
                                                                        :form-params {:clusterId ""
                                                                                      :enabled false
                                                                                      :name ""
                                                                                      :projectId ""
                                                                                      :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setLegacyAbac"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setLegacyAbac"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setLegacyAbac");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setLegacyAbac"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setLegacyAbac HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 88

{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setLegacyAbac")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setLegacyAbac"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setLegacyAbac")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setLegacyAbac")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  enabled: false,
  name: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setLegacyAbac',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', enabled: false, name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setLegacyAbac';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","enabled":false,"name":"","projectId":"","zone":""}'
};

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}}/v1beta1/:name:setLegacyAbac',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "enabled": false,\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setLegacyAbac")
  .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/v1beta1/:name:setLegacyAbac',
  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({clusterId: '', enabled: false, name: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setLegacyAbac',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', enabled: false, name: '', projectId: '', zone: ''},
  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}}/v1beta1/:name:setLegacyAbac');

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

req.type('json');
req.send({
  clusterId: '',
  enabled: false,
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:setLegacyAbac',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', enabled: false, name: '', projectId: '', zone: ''}
};

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

const url = '{{baseUrl}}/v1beta1/:name:setLegacyAbac';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","enabled":false,"name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"enabled": @NO,
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:setLegacyAbac"]
                                                       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}}/v1beta1/:name:setLegacyAbac" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setLegacyAbac",
  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([
    'clusterId' => '',
    'enabled' => null,
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setLegacyAbac', [
  'body' => '{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'enabled' => null,
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'enabled' => null,
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name:setLegacyAbac');
$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}}/v1beta1/:name:setLegacyAbac' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name:setLegacyAbac' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}'
import http.client

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

payload = "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setLegacyAbac", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setLegacyAbac"

payload = {
    "clusterId": "",
    "enabled": False,
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setLegacyAbac"

payload <- "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setLegacyAbac")

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  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setLegacyAbac') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "enabled": false,
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:setLegacyAbac \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setLegacyAbac \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "enabled": false,\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setLegacyAbac
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setLegacyAbac")! 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 container.projects.locations.clusters.setLocations
{{baseUrl}}/v1beta1/:name:setLocations
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setLocations" {:content-type :json
                                                                       :form-params {:clusterId ""
                                                                                     :locations []
                                                                                     :name ""
                                                                                     :projectId ""
                                                                                     :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setLocations"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setLocations"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setLocations");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setLocations"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setLocations HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 87

{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setLocations")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setLocations"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setLocations")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setLocations")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  locations: [],
  name: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setLocations',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', locations: [], name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setLocations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","locations":[],"name":"","projectId":"","zone":""}'
};

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}}/v1beta1/:name:setLocations',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "locations": [],\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setLocations")
  .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/v1beta1/:name:setLocations',
  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({clusterId: '', locations: [], name: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setLocations',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', locations: [], name: '', projectId: '', zone: ''},
  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}}/v1beta1/:name:setLocations');

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

req.type('json');
req.send({
  clusterId: '',
  locations: [],
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:setLocations',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', locations: [], name: '', projectId: '', zone: ''}
};

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

const url = '{{baseUrl}}/v1beta1/:name:setLocations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","locations":[],"name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"locations": @[  ],
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

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

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setLocations",
  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([
    'clusterId' => '',
    'locations' => [
        
    ],
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setLocations', [
  'body' => '{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'locations' => [
    
  ],
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

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

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

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

payload = "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setLocations", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setLocations"

payload = {
    "clusterId": "",
    "locations": [],
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setLocations"

payload <- "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setLocations")

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  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setLocations') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "locations": (),
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:setLocations \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setLocations \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "locations": [],\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setLocations
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setLocations")! 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 container.projects.locations.clusters.setLogging
{{baseUrl}}/v1beta1/:name:setLogging
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setLogging" {:content-type :json
                                                                     :form-params {:clusterId ""
                                                                                   :loggingService ""
                                                                                   :name ""
                                                                                   :projectId ""
                                                                                   :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setLogging"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setLogging"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setLogging");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setLogging"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setLogging HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 92

{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setLogging")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setLogging"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setLogging")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setLogging")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  loggingService: '',
  name: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setLogging',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', loggingService: '', name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setLogging';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","loggingService":"","name":"","projectId":"","zone":""}'
};

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}}/v1beta1/:name:setLogging',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "loggingService": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setLogging',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', loggingService: '', name: '', projectId: '', zone: ''},
  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}}/v1beta1/:name:setLogging');

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

req.type('json');
req.send({
  clusterId: '',
  loggingService: '',
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:setLogging',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', loggingService: '', name: '', projectId: '', zone: ''}
};

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

const url = '{{baseUrl}}/v1beta1/:name:setLogging';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","loggingService":"","name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"loggingService": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

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

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setLogging",
  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([
    'clusterId' => '',
    'loggingService' => '',
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setLogging', [
  'body' => '{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'loggingService' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

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

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

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

payload = "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setLogging", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setLogging"

payload = {
    "clusterId": "",
    "loggingService": "",
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setLogging"

payload <- "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setLogging")

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  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setLogging') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "loggingService": "",
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:setLogging \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setLogging \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "loggingService": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setLogging
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setLogging")! 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 container.projects.locations.clusters.setMaintenancePolicy
{{baseUrl}}/v1beta1/:name:setMaintenancePolicy
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setMaintenancePolicy" {:content-type :json
                                                                               :form-params {:clusterId ""
                                                                                             :maintenancePolicy {:resourceVersion ""
                                                                                                                 :window {:dailyMaintenanceWindow {:duration ""
                                                                                                                                                   :startTime ""}
                                                                                                                          :maintenanceExclusions {}
                                                                                                                          :recurringWindow {:recurrence ""
                                                                                                                                            :window {:endTime ""
                                                                                                                                                     :maintenanceExclusionOptions {:scope ""}
                                                                                                                                                     :startTime ""}}}}
                                                                                             :name ""
                                                                                             :projectId ""
                                                                                             :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setMaintenancePolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setMaintenancePolicy"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setMaintenancePolicy");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setMaintenancePolicy"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setMaintenancePolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 495

{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setMaintenancePolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setMaintenancePolicy"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setMaintenancePolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setMaintenancePolicy")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  maintenancePolicy: {
    resourceVersion: '',
    window: {
      dailyMaintenanceWindow: {
        duration: '',
        startTime: ''
      },
      maintenanceExclusions: {},
      recurringWindow: {
        recurrence: '',
        window: {
          endTime: '',
          maintenanceExclusionOptions: {
            scope: ''
          },
          startTime: ''
        }
      }
    }
  },
  name: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setMaintenancePolicy',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {duration: '', startTime: ''},
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
        }
      }
    },
    name: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setMaintenancePolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","maintenancePolicy":{"resourceVersion":"","window":{"dailyMaintenanceWindow":{"duration":"","startTime":""},"maintenanceExclusions":{},"recurringWindow":{"recurrence":"","window":{"endTime":"","maintenanceExclusionOptions":{"scope":""},"startTime":""}}}},"name":"","projectId":"","zone":""}'
};

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}}/v1beta1/:name:setMaintenancePolicy',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "maintenancePolicy": {\n    "resourceVersion": "",\n    "window": {\n      "dailyMaintenanceWindow": {\n        "duration": "",\n        "startTime": ""\n      },\n      "maintenanceExclusions": {},\n      "recurringWindow": {\n        "recurrence": "",\n        "window": {\n          "endTime": "",\n          "maintenanceExclusionOptions": {\n            "scope": ""\n          },\n          "startTime": ""\n        }\n      }\n    }\n  },\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setMaintenancePolicy")
  .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/v1beta1/:name:setMaintenancePolicy',
  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({
  clusterId: '',
  maintenancePolicy: {
    resourceVersion: '',
    window: {
      dailyMaintenanceWindow: {duration: '', startTime: ''},
      maintenanceExclusions: {},
      recurringWindow: {
        recurrence: '',
        window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
      }
    }
  },
  name: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setMaintenancePolicy',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {duration: '', startTime: ''},
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
        }
      }
    },
    name: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/:name:setMaintenancePolicy');

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

req.type('json');
req.send({
  clusterId: '',
  maintenancePolicy: {
    resourceVersion: '',
    window: {
      dailyMaintenanceWindow: {
        duration: '',
        startTime: ''
      },
      maintenanceExclusions: {},
      recurringWindow: {
        recurrence: '',
        window: {
          endTime: '',
          maintenanceExclusionOptions: {
            scope: ''
          },
          startTime: ''
        }
      }
    }
  },
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:setMaintenancePolicy',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {duration: '', startTime: ''},
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
        }
      }
    },
    name: '',
    projectId: '',
    zone: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:name:setMaintenancePolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","maintenancePolicy":{"resourceVersion":"","window":{"dailyMaintenanceWindow":{"duration":"","startTime":""},"maintenanceExclusions":{},"recurringWindow":{"recurrence":"","window":{"endTime":"","maintenanceExclusionOptions":{"scope":""},"startTime":""}}}},"name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"maintenancePolicy": @{ @"resourceVersion": @"", @"window": @{ @"dailyMaintenanceWindow": @{ @"duration": @"", @"startTime": @"" }, @"maintenanceExclusions": @{  }, @"recurringWindow": @{ @"recurrence": @"", @"window": @{ @"endTime": @"", @"maintenanceExclusionOptions": @{ @"scope": @"" }, @"startTime": @"" } } } },
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:setMaintenancePolicy"]
                                                       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}}/v1beta1/:name:setMaintenancePolicy" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setMaintenancePolicy",
  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([
    'clusterId' => '',
    'maintenancePolicy' => [
        'resourceVersion' => '',
        'window' => [
                'dailyMaintenanceWindow' => [
                                'duration' => '',
                                'startTime' => ''
                ],
                'maintenanceExclusions' => [
                                
                ],
                'recurringWindow' => [
                                'recurrence' => '',
                                'window' => [
                                                                'endTime' => '',
                                                                'maintenanceExclusionOptions' => [
                                                                                                                                'scope' => ''
                                                                ],
                                                                'startTime' => ''
                                ]
                ]
        ]
    ],
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setMaintenancePolicy', [
  'body' => '{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'maintenancePolicy' => [
    'resourceVersion' => '',
    'window' => [
        'dailyMaintenanceWindow' => [
                'duration' => '',
                'startTime' => ''
        ],
        'maintenanceExclusions' => [
                
        ],
        'recurringWindow' => [
                'recurrence' => '',
                'window' => [
                                'endTime' => '',
                                'maintenanceExclusionOptions' => [
                                                                'scope' => ''
                                ],
                                'startTime' => ''
                ]
        ]
    ]
  ],
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'maintenancePolicy' => [
    'resourceVersion' => '',
    'window' => [
        'dailyMaintenanceWindow' => [
                'duration' => '',
                'startTime' => ''
        ],
        'maintenanceExclusions' => [
                
        ],
        'recurringWindow' => [
                'recurrence' => '',
                'window' => [
                                'endTime' => '',
                                'maintenanceExclusionOptions' => [
                                                                'scope' => ''
                                ],
                                'startTime' => ''
                ]
        ]
    ]
  ],
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name:setMaintenancePolicy');
$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}}/v1beta1/:name:setMaintenancePolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name:setMaintenancePolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}'
import http.client

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

payload = "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setMaintenancePolicy", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setMaintenancePolicy"

payload = {
    "clusterId": "",
    "maintenancePolicy": {
        "resourceVersion": "",
        "window": {
            "dailyMaintenanceWindow": {
                "duration": "",
                "startTime": ""
            },
            "maintenanceExclusions": {},
            "recurringWindow": {
                "recurrence": "",
                "window": {
                    "endTime": "",
                    "maintenanceExclusionOptions": { "scope": "" },
                    "startTime": ""
                }
            }
        }
    },
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setMaintenancePolicy"

payload <- "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setMaintenancePolicy")

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  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setMaintenancePolicy') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "maintenancePolicy": json!({
            "resourceVersion": "",
            "window": json!({
                "dailyMaintenanceWindow": json!({
                    "duration": "",
                    "startTime": ""
                }),
                "maintenanceExclusions": json!({}),
                "recurringWindow": json!({
                    "recurrence": "",
                    "window": json!({
                        "endTime": "",
                        "maintenanceExclusionOptions": json!({"scope": ""}),
                        "startTime": ""
                    })
                })
            })
        }),
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:setMaintenancePolicy \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setMaintenancePolicy \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "maintenancePolicy": {\n    "resourceVersion": "",\n    "window": {\n      "dailyMaintenanceWindow": {\n        "duration": "",\n        "startTime": ""\n      },\n      "maintenanceExclusions": {},\n      "recurringWindow": {\n        "recurrence": "",\n        "window": {\n          "endTime": "",\n          "maintenanceExclusionOptions": {\n            "scope": ""\n          },\n          "startTime": ""\n        }\n      }\n    }\n  },\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setMaintenancePolicy
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "maintenancePolicy": [
    "resourceVersion": "",
    "window": [
      "dailyMaintenanceWindow": [
        "duration": "",
        "startTime": ""
      ],
      "maintenanceExclusions": [],
      "recurringWindow": [
        "recurrence": "",
        "window": [
          "endTime": "",
          "maintenanceExclusionOptions": ["scope": ""],
          "startTime": ""
        ]
      ]
    ]
  ],
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setMaintenancePolicy")! 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 container.projects.locations.clusters.setMasterAuth
{{baseUrl}}/v1beta1/:name:setMasterAuth
QUERY PARAMS

name
BODY json

{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setMasterAuth" {:content-type :json
                                                                        :form-params {:action ""
                                                                                      :clusterId ""
                                                                                      :name ""
                                                                                      :projectId ""
                                                                                      :update {:clientCertificate ""
                                                                                               :clientCertificateConfig {:issueClientCertificate false}
                                                                                               :clientKey ""
                                                                                               :clusterCaCertificate ""
                                                                                               :password ""
                                                                                               :username ""}
                                                                                      :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setMasterAuth"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/:name:setMasterAuth"),
    Content = new StringContent("{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/:name:setMasterAuth");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setMasterAuth"

	payload := strings.NewReader("{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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/v1beta1/:name:setMasterAuth HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 302

{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setMasterAuth")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setMasterAuth"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setMasterAuth")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setMasterAuth")
  .header("content-type", "application/json")
  .body("{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  action: '',
  clusterId: '',
  name: '',
  projectId: '',
  update: {
    clientCertificate: '',
    clientCertificateConfig: {
      issueClientCertificate: false
    },
    clientKey: '',
    clusterCaCertificate: '',
    password: '',
    username: ''
  },
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setMasterAuth',
  headers: {'content-type': 'application/json'},
  data: {
    action: '',
    clusterId: '',
    name: '',
    projectId: '',
    update: {
      clientCertificate: '',
      clientCertificateConfig: {issueClientCertificate: false},
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setMasterAuth';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"action":"","clusterId":"","name":"","projectId":"","update":{"clientCertificate":"","clientCertificateConfig":{"issueClientCertificate":false},"clientKey":"","clusterCaCertificate":"","password":"","username":""},"zone":""}'
};

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}}/v1beta1/:name:setMasterAuth',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "action": "",\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "update": {\n    "clientCertificate": "",\n    "clientCertificateConfig": {\n      "issueClientCertificate": false\n    },\n    "clientKey": "",\n    "clusterCaCertificate": "",\n    "password": "",\n    "username": ""\n  },\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setMasterAuth")
  .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/v1beta1/:name:setMasterAuth',
  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({
  action: '',
  clusterId: '',
  name: '',
  projectId: '',
  update: {
    clientCertificate: '',
    clientCertificateConfig: {issueClientCertificate: false},
    clientKey: '',
    clusterCaCertificate: '',
    password: '',
    username: ''
  },
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setMasterAuth',
  headers: {'content-type': 'application/json'},
  body: {
    action: '',
    clusterId: '',
    name: '',
    projectId: '',
    update: {
      clientCertificate: '',
      clientCertificateConfig: {issueClientCertificate: false},
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    zone: ''
  },
  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}}/v1beta1/:name:setMasterAuth');

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

req.type('json');
req.send({
  action: '',
  clusterId: '',
  name: '',
  projectId: '',
  update: {
    clientCertificate: '',
    clientCertificateConfig: {
      issueClientCertificate: false
    },
    clientKey: '',
    clusterCaCertificate: '',
    password: '',
    username: ''
  },
  zone: ''
});

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}}/v1beta1/:name:setMasterAuth',
  headers: {'content-type': 'application/json'},
  data: {
    action: '',
    clusterId: '',
    name: '',
    projectId: '',
    update: {
      clientCertificate: '',
      clientCertificateConfig: {issueClientCertificate: false},
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    zone: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:name:setMasterAuth';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"action":"","clusterId":"","name":"","projectId":"","update":{"clientCertificate":"","clientCertificateConfig":{"issueClientCertificate":false},"clientKey":"","clusterCaCertificate":"","password":"","username":""},"zone":""}'
};

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 = @{ @"action": @"",
                              @"clusterId": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"update": @{ @"clientCertificate": @"", @"clientCertificateConfig": @{ @"issueClientCertificate": @NO }, @"clientKey": @"", @"clusterCaCertificate": @"", @"password": @"", @"username": @"" },
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:setMasterAuth"]
                                                       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}}/v1beta1/:name:setMasterAuth" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setMasterAuth",
  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([
    'action' => '',
    'clusterId' => '',
    'name' => '',
    'projectId' => '',
    'update' => [
        'clientCertificate' => '',
        'clientCertificateConfig' => [
                'issueClientCertificate' => null
        ],
        'clientKey' => '',
        'clusterCaCertificate' => '',
        'password' => '',
        'username' => ''
    ],
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setMasterAuth', [
  'body' => '{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'action' => '',
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'update' => [
    'clientCertificate' => '',
    'clientCertificateConfig' => [
        'issueClientCertificate' => null
    ],
    'clientKey' => '',
    'clusterCaCertificate' => '',
    'password' => '',
    'username' => ''
  ],
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'action' => '',
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'update' => [
    'clientCertificate' => '',
    'clientCertificateConfig' => [
        'issueClientCertificate' => null
    ],
    'clientKey' => '',
    'clusterCaCertificate' => '',
    'password' => '',
    'username' => ''
  ],
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name:setMasterAuth');
$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}}/v1beta1/:name:setMasterAuth' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name:setMasterAuth' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}'
import http.client

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

payload = "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setMasterAuth", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setMasterAuth"

payload = {
    "action": "",
    "clusterId": "",
    "name": "",
    "projectId": "",
    "update": {
        "clientCertificate": "",
        "clientCertificateConfig": { "issueClientCertificate": False },
        "clientKey": "",
        "clusterCaCertificate": "",
        "password": "",
        "username": ""
    },
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setMasterAuth"

payload <- "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/:name:setMasterAuth")

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  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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/v1beta1/:name:setMasterAuth') do |req|
  req.body = "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "action": "",
        "clusterId": "",
        "name": "",
        "projectId": "",
        "update": json!({
            "clientCertificate": "",
            "clientCertificateConfig": json!({"issueClientCertificate": false}),
            "clientKey": "",
            "clusterCaCertificate": "",
            "password": "",
            "username": ""
        }),
        "zone": ""
    });

    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}}/v1beta1/:name:setMasterAuth \
  --header 'content-type: application/json' \
  --data '{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}'
echo '{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setMasterAuth \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "action": "",\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "update": {\n    "clientCertificate": "",\n    "clientCertificateConfig": {\n      "issueClientCertificate": false\n    },\n    "clientKey": "",\n    "clusterCaCertificate": "",\n    "password": "",\n    "username": ""\n  },\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setMasterAuth
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": [
    "clientCertificate": "",
    "clientCertificateConfig": ["issueClientCertificate": false],
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  ],
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setMasterAuth")! 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 container.projects.locations.clusters.setMonitoring
{{baseUrl}}/v1beta1/:name:setMonitoring
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setMonitoring" {:content-type :json
                                                                        :form-params {:clusterId ""
                                                                                      :monitoringService ""
                                                                                      :name ""
                                                                                      :projectId ""
                                                                                      :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setMonitoring"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setMonitoring"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setMonitoring");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setMonitoring"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setMonitoring HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 95

{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setMonitoring")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setMonitoring"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setMonitoring")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setMonitoring")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  monitoringService: '',
  name: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setMonitoring',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', monitoringService: '', name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setMonitoring';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","monitoringService":"","name":"","projectId":"","zone":""}'
};

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}}/v1beta1/:name:setMonitoring',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "monitoringService": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setMonitoring',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', monitoringService: '', name: '', projectId: '', zone: ''},
  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}}/v1beta1/:name:setMonitoring');

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

req.type('json');
req.send({
  clusterId: '',
  monitoringService: '',
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:setMonitoring',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', monitoringService: '', name: '', projectId: '', zone: ''}
};

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

const url = '{{baseUrl}}/v1beta1/:name:setMonitoring';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","monitoringService":"","name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"monitoringService": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

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

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setMonitoring",
  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([
    'clusterId' => '',
    'monitoringService' => '',
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setMonitoring', [
  'body' => '{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'monitoringService' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

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

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

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

payload = "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setMonitoring", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setMonitoring"

payload = {
    "clusterId": "",
    "monitoringService": "",
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setMonitoring"

payload <- "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setMonitoring")

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  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setMonitoring') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "monitoringService": "",
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:setMonitoring \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setMonitoring \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "monitoringService": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setMonitoring
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setMonitoring")! 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 container.projects.locations.clusters.setNetworkPolicy
{{baseUrl}}/v1beta1/:name:setNetworkPolicy
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setNetworkPolicy" {:content-type :json
                                                                           :form-params {:clusterId ""
                                                                                         :name ""
                                                                                         :networkPolicy {:enabled false
                                                                                                         :provider ""}
                                                                                         :projectId ""
                                                                                         :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setNetworkPolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setNetworkPolicy"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setNetworkPolicy");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setNetworkPolicy"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setNetworkPolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 135

{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setNetworkPolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setNetworkPolicy"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setNetworkPolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setNetworkPolicy")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  name: '',
  networkPolicy: {
    enabled: false,
    provider: ''
  },
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setNetworkPolicy',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    name: '',
    networkPolicy: {enabled: false, provider: ''},
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setNetworkPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","networkPolicy":{"enabled":false,"provider":""},"projectId":"","zone":""}'
};

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}}/v1beta1/:name:setNetworkPolicy',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "name": "",\n  "networkPolicy": {\n    "enabled": false,\n    "provider": ""\n  },\n  "projectId": "",\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setNetworkPolicy")
  .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/v1beta1/:name:setNetworkPolicy',
  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({
  clusterId: '',
  name: '',
  networkPolicy: {enabled: false, provider: ''},
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setNetworkPolicy',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    name: '',
    networkPolicy: {enabled: false, provider: ''},
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/:name:setNetworkPolicy');

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

req.type('json');
req.send({
  clusterId: '',
  name: '',
  networkPolicy: {
    enabled: false,
    provider: ''
  },
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:setNetworkPolicy',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    name: '',
    networkPolicy: {enabled: false, provider: ''},
    projectId: '',
    zone: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:name:setNetworkPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","networkPolicy":{"enabled":false,"provider":""},"projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"name": @"",
                              @"networkPolicy": @{ @"enabled": @NO, @"provider": @"" },
                              @"projectId": @"",
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:setNetworkPolicy"]
                                                       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}}/v1beta1/:name:setNetworkPolicy" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setNetworkPolicy",
  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([
    'clusterId' => '',
    'name' => '',
    'networkPolicy' => [
        'enabled' => null,
        'provider' => ''
    ],
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setNetworkPolicy', [
  'body' => '{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'name' => '',
  'networkPolicy' => [
    'enabled' => null,
    'provider' => ''
  ],
  'projectId' => '',
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'name' => '',
  'networkPolicy' => [
    'enabled' => null,
    'provider' => ''
  ],
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name:setNetworkPolicy');
$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}}/v1beta1/:name:setNetworkPolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name:setNetworkPolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}'
import http.client

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

payload = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setNetworkPolicy", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setNetworkPolicy"

payload = {
    "clusterId": "",
    "name": "",
    "networkPolicy": {
        "enabled": False,
        "provider": ""
    },
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setNetworkPolicy"

payload <- "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:setNetworkPolicy")

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:setNetworkPolicy') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "name": "",
        "networkPolicy": json!({
            "enabled": false,
            "provider": ""
        }),
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:setNetworkPolicy \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setNetworkPolicy \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "name": "",\n  "networkPolicy": {\n    "enabled": false,\n    "provider": ""\n  },\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setNetworkPolicy
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "name": "",
  "networkPolicy": [
    "enabled": false,
    "provider": ""
  ],
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setNetworkPolicy")! 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 container.projects.locations.clusters.setResourceLabels
{{baseUrl}}/v1beta1/:name:setResourceLabels
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:setResourceLabels" {:content-type :json
                                                                            :form-params {:clusterId ""
                                                                                          :labelFingerprint ""
                                                                                          :name ""
                                                                                          :projectId ""
                                                                                          :resourceLabels {}
                                                                                          :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:setResourceLabels"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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}}/v1beta1/:name:setResourceLabels"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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}}/v1beta1/:name:setResourceLabels");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:setResourceLabels"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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/v1beta1/:name:setResourceLabels HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 118

{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:setResourceLabels")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:setResourceLabels"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setResourceLabels")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:setResourceLabels")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  labelFingerprint: '',
  name: '',
  projectId: '',
  resourceLabels: {},
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setResourceLabels',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    labelFingerprint: '',
    name: '',
    projectId: '',
    resourceLabels: {},
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:setResourceLabels';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","labelFingerprint":"","name":"","projectId":"","resourceLabels":{},"zone":""}'
};

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}}/v1beta1/:name:setResourceLabels',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "labelFingerprint": "",\n  "name": "",\n  "projectId": "",\n  "resourceLabels": {},\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:setResourceLabels")
  .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/v1beta1/:name:setResourceLabels',
  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({
  clusterId: '',
  labelFingerprint: '',
  name: '',
  projectId: '',
  resourceLabels: {},
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:setResourceLabels',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    labelFingerprint: '',
    name: '',
    projectId: '',
    resourceLabels: {},
    zone: ''
  },
  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}}/v1beta1/:name:setResourceLabels');

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

req.type('json');
req.send({
  clusterId: '',
  labelFingerprint: '',
  name: '',
  projectId: '',
  resourceLabels: {},
  zone: ''
});

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}}/v1beta1/:name:setResourceLabels',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    labelFingerprint: '',
    name: '',
    projectId: '',
    resourceLabels: {},
    zone: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:name:setResourceLabels';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","labelFingerprint":"","name":"","projectId":"","resourceLabels":{},"zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"labelFingerprint": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"resourceLabels": @{  },
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:setResourceLabels"]
                                                       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}}/v1beta1/:name:setResourceLabels" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:setResourceLabels",
  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([
    'clusterId' => '',
    'labelFingerprint' => '',
    'name' => '',
    'projectId' => '',
    'resourceLabels' => [
        
    ],
    'zone' => ''
  ]),
  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}}/v1beta1/:name:setResourceLabels', [
  'body' => '{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'labelFingerprint' => '',
  'name' => '',
  'projectId' => '',
  'resourceLabels' => [
    
  ],
  'zone' => ''
]));

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

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

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

payload = "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:setResourceLabels", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:setResourceLabels"

payload = {
    "clusterId": "",
    "labelFingerprint": "",
    "name": "",
    "projectId": "",
    "resourceLabels": {},
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:setResourceLabels"

payload <- "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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}}/v1beta1/:name:setResourceLabels")

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  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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/v1beta1/:name:setResourceLabels') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "labelFingerprint": "",
        "name": "",
        "projectId": "",
        "resourceLabels": json!({}),
        "zone": ""
    });

    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}}/v1beta1/:name:setResourceLabels \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}'
echo '{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:setResourceLabels \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "labelFingerprint": "",\n  "name": "",\n  "projectId": "",\n  "resourceLabels": {},\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:setResourceLabels
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": [],
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:setResourceLabels")! 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 container.projects.locations.clusters.startIpRotation
{{baseUrl}}/v1beta1/:name:startIpRotation
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:startIpRotation" {:content-type :json
                                                                          :form-params {:clusterId ""
                                                                                        :name ""
                                                                                        :projectId ""
                                                                                        :rotateCredentials false
                                                                                        :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:startIpRotation"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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}}/v1beta1/:name:startIpRotation"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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}}/v1beta1/:name:startIpRotation");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:startIpRotation"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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/v1beta1/:name:startIpRotation HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 98

{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:startIpRotation")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:startIpRotation"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:startIpRotation")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:startIpRotation")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  name: '',
  projectId: '',
  rotateCredentials: false,
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:startIpRotation',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', projectId: '', rotateCredentials: false, zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:startIpRotation';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","projectId":"","rotateCredentials":false,"zone":""}'
};

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}}/v1beta1/:name:startIpRotation',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "rotateCredentials": false,\n  "zone": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:startIpRotation")
  .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/v1beta1/:name:startIpRotation',
  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({clusterId: '', name: '', projectId: '', rotateCredentials: false, zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:startIpRotation',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', name: '', projectId: '', rotateCredentials: false, zone: ''},
  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}}/v1beta1/:name:startIpRotation');

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

req.type('json');
req.send({
  clusterId: '',
  name: '',
  projectId: '',
  rotateCredentials: false,
  zone: ''
});

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}}/v1beta1/:name:startIpRotation',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', projectId: '', rotateCredentials: false, zone: ''}
};

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

const url = '{{baseUrl}}/v1beta1/:name:startIpRotation';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","projectId":"","rotateCredentials":false,"zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"rotateCredentials": @NO,
                              @"zone": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:startIpRotation"]
                                                       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}}/v1beta1/:name:startIpRotation" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:startIpRotation",
  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([
    'clusterId' => '',
    'name' => '',
    'projectId' => '',
    'rotateCredentials' => null,
    'zone' => ''
  ]),
  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}}/v1beta1/:name:startIpRotation', [
  'body' => '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'rotateCredentials' => null,
  'zone' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'rotateCredentials' => null,
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name:startIpRotation');
$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}}/v1beta1/:name:startIpRotation' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name:startIpRotation' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}'
import http.client

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

payload = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:startIpRotation", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:startIpRotation"

payload = {
    "clusterId": "",
    "name": "",
    "projectId": "",
    "rotateCredentials": False,
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:startIpRotation"

payload <- "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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}}/v1beta1/:name:startIpRotation")

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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/v1beta1/:name:startIpRotation') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "name": "",
        "projectId": "",
        "rotateCredentials": false,
        "zone": ""
    });

    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}}/v1beta1/:name:startIpRotation \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}'
echo '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:startIpRotation \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "rotateCredentials": false,\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:startIpRotation
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:startIpRotation")! 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 container.projects.locations.clusters.updateMaster
{{baseUrl}}/v1beta1/:name:updateMaster
QUERY PARAMS

name
BODY json

{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:name:updateMaster" {:content-type :json
                                                                       :form-params {:clusterId ""
                                                                                     :masterVersion ""
                                                                                     :name ""
                                                                                     :projectId ""
                                                                                     :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:updateMaster"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:updateMaster"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:updateMaster");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name:updateMaster"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:updateMaster HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 91

{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:updateMaster")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:updateMaster"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:updateMaster")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:updateMaster")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  masterVersion: '',
  name: '',
  projectId: '',
  zone: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:updateMaster',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', masterVersion: '', name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:updateMaster';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","masterVersion":"","name":"","projectId":"","zone":""}'
};

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}}/v1beta1/:name:updateMaster',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "masterVersion": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:updateMaster',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', masterVersion: '', name: '', projectId: '', zone: ''},
  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}}/v1beta1/:name:updateMaster');

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

req.type('json');
req.send({
  clusterId: '',
  masterVersion: '',
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:updateMaster',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', masterVersion: '', name: '', projectId: '', zone: ''}
};

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

const url = '{{baseUrl}}/v1beta1/:name:updateMaster';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","masterVersion":"","name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"masterVersion": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

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

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

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:updateMaster",
  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([
    'clusterId' => '',
    'masterVersion' => '',
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:updateMaster', [
  'body' => '{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'masterVersion' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

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

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

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

payload = "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v1beta1/:name:updateMaster", payload, headers)

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

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

url = "{{baseUrl}}/v1beta1/:name:updateMaster"

payload = {
    "clusterId": "",
    "masterVersion": "",
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:name:updateMaster"

payload <- "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:updateMaster")

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  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:updateMaster') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

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

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

    let payload = json!({
        "clusterId": "",
        "masterVersion": "",
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:updateMaster \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:updateMaster \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "masterVersion": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:updateMaster
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:updateMaster")! 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 container.projects.locations.clusters.well-known.getOpenid-configuration
{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration");

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

(client/get "{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration")
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration"

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

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

func main() {

	url := "{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration"

	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/v1beta1/:parent/.well-known/openid-configuration HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

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

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

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration'
};

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

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

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration")
  .get()
  .build()

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

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/:parent/.well-known/openid-configuration',
  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}}/v1beta1/:parent/.well-known/openid-configuration'
};

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

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

const req = unirest('GET', '{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration');

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}}/v1beta1/:parent/.well-known/openid-configuration'
};

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

const url = '{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration';
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}}/v1beta1/:parent/.well-known/openid-configuration"]
                                                       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}}/v1beta1/:parent/.well-known/openid-configuration" in

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

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration');
$request->setMethod(HTTP_METH_GET);

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration' -Method GET 
import http.client

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

conn.request("GET", "/baseUrl/v1beta1/:parent/.well-known/openid-configuration")

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

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

url = "{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration"

response = requests.get(url)

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

url <- "{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration"

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

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

url = URI("{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration")

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/v1beta1/:parent/.well-known/openid-configuration') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration";

    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}}/v1beta1/:parent/.well-known/openid-configuration
http GET {{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/.well-known/openid-configuration")! 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 container.projects.locations.getServerConfig
{{baseUrl}}/v1beta1/:name/serverConfig
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

url = "{{baseUrl}}/v1beta1/:name/serverConfig"

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

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

func main() {

	url := "{{baseUrl}}/v1beta1/:name/serverConfig"

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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}}/v1beta1/:name/serverConfig'};

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

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

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

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

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

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

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

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

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

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

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

url = "{{baseUrl}}/v1beta1/:name/serverConfig"

response = requests.get(url)

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

url <- "{{baseUrl}}/v1beta1/:name/serverConfig"

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name/serverConfig")! 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 container.projects.locations.list
{{baseUrl}}/v1beta1/:parent/locations
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

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

func main() {

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

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

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

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

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

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

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

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

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

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

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

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v1beta1/:parent/locations');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/locations'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent/locations';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:parent/locations',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/locations")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/:parent/locations',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/locations'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1beta1/:parent/locations');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/locations'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/:parent/locations';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:parent/locations"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:parent/locations" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:parent/locations",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v1beta1/:parent/locations');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/:parent/locations');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/:parent/locations');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:parent/locations' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent/locations' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/:parent/locations")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/:parent/locations"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/:parent/locations"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/:parent/locations")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/v1beta1/:parent/locations') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/:parent/locations";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v1beta1/:parent/locations
http GET {{baseUrl}}/v1beta1/:parent/locations
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/locations
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/locations")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST container.projects.locations.operations.cancel
{{baseUrl}}/v1beta1/:name:cancel
QUERY PARAMS

name
BODY json

{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/:name:cancel");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/:name:cancel" {:content-type :json
                                                                 :form-params {:name ""
                                                                               :operationId ""
                                                                               :projectId ""
                                                                               :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name:cancel"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:cancel"),
    Content = new StringContent("{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:cancel");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/:name:cancel"

	payload := strings.NewReader("{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:cancel HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 70

{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:name:cancel")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name:cancel"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:cancel")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:name:cancel")
  .header("content-type", "application/json")
  .body("{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  name: '',
  operationId: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/:name:cancel');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:cancel',
  headers: {'content-type': 'application/json'},
  data: {name: '', operationId: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name:cancel';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","operationId":"","projectId":"","zone":""}'
};

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}}/v1beta1/:name:cancel',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name": "",\n  "operationId": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name:cancel")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/:name:cancel',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({name: '', operationId: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:name:cancel',
  headers: {'content-type': 'application/json'},
  body: {name: '', operationId: '', projectId: '', zone: ''},
  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}}/v1beta1/:name:cancel');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  name: '',
  operationId: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/:name:cancel',
  headers: {'content-type': 'application/json'},
  data: {name: '', operationId: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/:name:cancel';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","operationId":"","projectId":"","zone":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"name": @"",
                              @"operationId": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name:cancel"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:name:cancel" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name:cancel",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'name' => '',
    'operationId' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/:name:cancel', [
  'body' => '{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/:name:cancel');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name' => '',
  'operationId' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name' => '',
  'operationId' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name:cancel');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:name:cancel' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name:cancel' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/:name:cancel", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/:name:cancel"

payload = {
    "name": "",
    "operationId": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/:name:cancel"

payload <- "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/:name:cancel")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/:name:cancel') do |req|
  req.body = "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/:name:cancel";

    let payload = json!({
        "name": "",
        "operationId": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/:name:cancel \
  --header 'content-type: application/json' \
  --data '{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:name:cancel \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": "",\n  "operationId": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name:cancel
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name:cancel")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET container.projects.locations.operations.get
{{baseUrl}}/v1beta1/:name
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/:name");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1beta1/:name")
require "http/client"

url = "{{baseUrl}}/v1beta1/:name"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/v1beta1/:name"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/:name");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/:name"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/v1beta1/:name HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1beta1/:name")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1beta1/:name")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v1beta1/:name');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:name'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:name',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/:name',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:name'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1beta1/:name');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:name'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/:name';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:name" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v1beta1/:name');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/:name');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/:name');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:name' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/:name")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/:name"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/:name"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/:name")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/v1beta1/:name') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/:name";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v1beta1/:name
http GET {{baseUrl}}/v1beta1/:name
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/:name
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET container.projects.locations.operations.list
{{baseUrl}}/v1beta1/:parent/operations
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/:parent/operations");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1beta1/:parent/operations")
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/operations"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/v1beta1/:parent/operations"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/:parent/operations");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/:parent/operations"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/v1beta1/:parent/operations HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1beta1/:parent/operations")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:parent/operations"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/operations")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1beta1/:parent/operations")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v1beta1/:parent/operations');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/operations'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent/operations';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:parent/operations',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/operations")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/:parent/operations',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/operations'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1beta1/:parent/operations');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/operations'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/:parent/operations';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:parent/operations"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:parent/operations" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:parent/operations",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v1beta1/:parent/operations');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/:parent/operations');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/:parent/operations');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:parent/operations' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent/operations' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/:parent/operations")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/:parent/operations"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/:parent/operations"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/:parent/operations")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/v1beta1/:parent/operations') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/:parent/operations";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v1beta1/:parent/operations
http GET {{baseUrl}}/v1beta1/:parent/operations
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/operations
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/operations")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
POST container.projects.zones.clusters.addons
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons");

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  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons" {:content-type :json
                                                                                                               :form-params {:addonsConfig {:cloudRunConfig {:disabled false
                                                                                                                                                             :loadBalancerType ""}
                                                                                                                                            :configConnectorConfig {:enabled false}
                                                                                                                                            :dnsCacheConfig {:enabled false}
                                                                                                                                            :gcePersistentDiskCsiDriverConfig {:enabled false}
                                                                                                                                            :gcpFilestoreCsiDriverConfig {:enabled false}
                                                                                                                                            :gkeBackupAgentConfig {:enabled false}
                                                                                                                                            :horizontalPodAutoscaling {:disabled false}
                                                                                                                                            :httpLoadBalancing {:disabled false}
                                                                                                                                            :istioConfig {:auth ""
                                                                                                                                                          :disabled false}
                                                                                                                                            :kalmConfig {:enabled false}
                                                                                                                                            :kubernetesDashboard {:disabled false}
                                                                                                                                            :networkPolicyConfig {:disabled false}}
                                                                                                                             :clusterId ""
                                                                                                                             :name ""
                                                                                                                             :projectId ""
                                                                                                                             :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons"),
    Content = new StringContent("{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons"

	payload := strings.NewReader("{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 854

{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons")
  .header("content-type", "application/json")
  .body("{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  addonsConfig: {
    cloudRunConfig: {
      disabled: false,
      loadBalancerType: ''
    },
    configConnectorConfig: {
      enabled: false
    },
    dnsCacheConfig: {
      enabled: false
    },
    gcePersistentDiskCsiDriverConfig: {
      enabled: false
    },
    gcpFilestoreCsiDriverConfig: {
      enabled: false
    },
    gkeBackupAgentConfig: {
      enabled: false
    },
    horizontalPodAutoscaling: {
      disabled: false
    },
    httpLoadBalancing: {
      disabled: false
    },
    istioConfig: {
      auth: '',
      disabled: false
    },
    kalmConfig: {
      enabled: false
    },
    kubernetesDashboard: {
      disabled: false
    },
    networkPolicyConfig: {
      disabled: false
    }
  },
  clusterId: '',
  name: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons',
  headers: {'content-type': 'application/json'},
  data: {
    addonsConfig: {
      cloudRunConfig: {disabled: false, loadBalancerType: ''},
      configConnectorConfig: {enabled: false},
      dnsCacheConfig: {enabled: false},
      gcePersistentDiskCsiDriverConfig: {enabled: false},
      gcpFilestoreCsiDriverConfig: {enabled: false},
      gkeBackupAgentConfig: {enabled: false},
      horizontalPodAutoscaling: {disabled: false},
      httpLoadBalancing: {disabled: false},
      istioConfig: {auth: '', disabled: false},
      kalmConfig: {enabled: false},
      kubernetesDashboard: {disabled: false},
      networkPolicyConfig: {disabled: false}
    },
    clusterId: '',
    name: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addonsConfig":{"cloudRunConfig":{"disabled":false,"loadBalancerType":""},"configConnectorConfig":{"enabled":false},"dnsCacheConfig":{"enabled":false},"gcePersistentDiskCsiDriverConfig":{"enabled":false},"gcpFilestoreCsiDriverConfig":{"enabled":false},"gkeBackupAgentConfig":{"enabled":false},"horizontalPodAutoscaling":{"disabled":false},"httpLoadBalancing":{"disabled":false},"istioConfig":{"auth":"","disabled":false},"kalmConfig":{"enabled":false},"kubernetesDashboard":{"disabled":false},"networkPolicyConfig":{"disabled":false}},"clusterId":"","name":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "addonsConfig": {\n    "cloudRunConfig": {\n      "disabled": false,\n      "loadBalancerType": ""\n    },\n    "configConnectorConfig": {\n      "enabled": false\n    },\n    "dnsCacheConfig": {\n      "enabled": false\n    },\n    "gcePersistentDiskCsiDriverConfig": {\n      "enabled": false\n    },\n    "gcpFilestoreCsiDriverConfig": {\n      "enabled": false\n    },\n    "gkeBackupAgentConfig": {\n      "enabled": false\n    },\n    "horizontalPodAutoscaling": {\n      "disabled": false\n    },\n    "httpLoadBalancing": {\n      "disabled": false\n    },\n    "istioConfig": {\n      "auth": "",\n      "disabled": false\n    },\n    "kalmConfig": {\n      "enabled": false\n    },\n    "kubernetesDashboard": {\n      "disabled": false\n    },\n    "networkPolicyConfig": {\n      "disabled": false\n    }\n  },\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons',
  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({
  addonsConfig: {
    cloudRunConfig: {disabled: false, loadBalancerType: ''},
    configConnectorConfig: {enabled: false},
    dnsCacheConfig: {enabled: false},
    gcePersistentDiskCsiDriverConfig: {enabled: false},
    gcpFilestoreCsiDriverConfig: {enabled: false},
    gkeBackupAgentConfig: {enabled: false},
    horizontalPodAutoscaling: {disabled: false},
    httpLoadBalancing: {disabled: false},
    istioConfig: {auth: '', disabled: false},
    kalmConfig: {enabled: false},
    kubernetesDashboard: {disabled: false},
    networkPolicyConfig: {disabled: false}
  },
  clusterId: '',
  name: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons',
  headers: {'content-type': 'application/json'},
  body: {
    addonsConfig: {
      cloudRunConfig: {disabled: false, loadBalancerType: ''},
      configConnectorConfig: {enabled: false},
      dnsCacheConfig: {enabled: false},
      gcePersistentDiskCsiDriverConfig: {enabled: false},
      gcpFilestoreCsiDriverConfig: {enabled: false},
      gkeBackupAgentConfig: {enabled: false},
      horizontalPodAutoscaling: {disabled: false},
      httpLoadBalancing: {disabled: false},
      istioConfig: {auth: '', disabled: false},
      kalmConfig: {enabled: false},
      kubernetesDashboard: {disabled: false},
      networkPolicyConfig: {disabled: false}
    },
    clusterId: '',
    name: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  addonsConfig: {
    cloudRunConfig: {
      disabled: false,
      loadBalancerType: ''
    },
    configConnectorConfig: {
      enabled: false
    },
    dnsCacheConfig: {
      enabled: false
    },
    gcePersistentDiskCsiDriverConfig: {
      enabled: false
    },
    gcpFilestoreCsiDriverConfig: {
      enabled: false
    },
    gkeBackupAgentConfig: {
      enabled: false
    },
    horizontalPodAutoscaling: {
      disabled: false
    },
    httpLoadBalancing: {
      disabled: false
    },
    istioConfig: {
      auth: '',
      disabled: false
    },
    kalmConfig: {
      enabled: false
    },
    kubernetesDashboard: {
      disabled: false
    },
    networkPolicyConfig: {
      disabled: false
    }
  },
  clusterId: '',
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons',
  headers: {'content-type': 'application/json'},
  data: {
    addonsConfig: {
      cloudRunConfig: {disabled: false, loadBalancerType: ''},
      configConnectorConfig: {enabled: false},
      dnsCacheConfig: {enabled: false},
      gcePersistentDiskCsiDriverConfig: {enabled: false},
      gcpFilestoreCsiDriverConfig: {enabled: false},
      gkeBackupAgentConfig: {enabled: false},
      horizontalPodAutoscaling: {disabled: false},
      httpLoadBalancing: {disabled: false},
      istioConfig: {auth: '', disabled: false},
      kalmConfig: {enabled: false},
      kubernetesDashboard: {disabled: false},
      networkPolicyConfig: {disabled: false}
    },
    clusterId: '',
    name: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"addonsConfig":{"cloudRunConfig":{"disabled":false,"loadBalancerType":""},"configConnectorConfig":{"enabled":false},"dnsCacheConfig":{"enabled":false},"gcePersistentDiskCsiDriverConfig":{"enabled":false},"gcpFilestoreCsiDriverConfig":{"enabled":false},"gkeBackupAgentConfig":{"enabled":false},"horizontalPodAutoscaling":{"disabled":false},"httpLoadBalancing":{"disabled":false},"istioConfig":{"auth":"","disabled":false},"kalmConfig":{"enabled":false},"kubernetesDashboard":{"disabled":false},"networkPolicyConfig":{"disabled":false}},"clusterId":"","name":"","projectId":"","zone":""}'
};

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 = @{ @"addonsConfig": @{ @"cloudRunConfig": @{ @"disabled": @NO, @"loadBalancerType": @"" }, @"configConnectorConfig": @{ @"enabled": @NO }, @"dnsCacheConfig": @{ @"enabled": @NO }, @"gcePersistentDiskCsiDriverConfig": @{ @"enabled": @NO }, @"gcpFilestoreCsiDriverConfig": @{ @"enabled": @NO }, @"gkeBackupAgentConfig": @{ @"enabled": @NO }, @"horizontalPodAutoscaling": @{ @"disabled": @NO }, @"httpLoadBalancing": @{ @"disabled": @NO }, @"istioConfig": @{ @"auth": @"", @"disabled": @NO }, @"kalmConfig": @{ @"enabled": @NO }, @"kubernetesDashboard": @{ @"disabled": @NO }, @"networkPolicyConfig": @{ @"disabled": @NO } },
                              @"clusterId": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons",
  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([
    'addonsConfig' => [
        'cloudRunConfig' => [
                'disabled' => null,
                'loadBalancerType' => ''
        ],
        'configConnectorConfig' => [
                'enabled' => null
        ],
        'dnsCacheConfig' => [
                'enabled' => null
        ],
        'gcePersistentDiskCsiDriverConfig' => [
                'enabled' => null
        ],
        'gcpFilestoreCsiDriverConfig' => [
                'enabled' => null
        ],
        'gkeBackupAgentConfig' => [
                'enabled' => null
        ],
        'horizontalPodAutoscaling' => [
                'disabled' => null
        ],
        'httpLoadBalancing' => [
                'disabled' => null
        ],
        'istioConfig' => [
                'auth' => '',
                'disabled' => null
        ],
        'kalmConfig' => [
                'enabled' => null
        ],
        'kubernetesDashboard' => [
                'disabled' => null
        ],
        'networkPolicyConfig' => [
                'disabled' => null
        ]
    ],
    'clusterId' => '',
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons', [
  'body' => '{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'addonsConfig' => [
    'cloudRunConfig' => [
        'disabled' => null,
        'loadBalancerType' => ''
    ],
    'configConnectorConfig' => [
        'enabled' => null
    ],
    'dnsCacheConfig' => [
        'enabled' => null
    ],
    'gcePersistentDiskCsiDriverConfig' => [
        'enabled' => null
    ],
    'gcpFilestoreCsiDriverConfig' => [
        'enabled' => null
    ],
    'gkeBackupAgentConfig' => [
        'enabled' => null
    ],
    'horizontalPodAutoscaling' => [
        'disabled' => null
    ],
    'httpLoadBalancing' => [
        'disabled' => null
    ],
    'istioConfig' => [
        'auth' => '',
        'disabled' => null
    ],
    'kalmConfig' => [
        'enabled' => null
    ],
    'kubernetesDashboard' => [
        'disabled' => null
    ],
    'networkPolicyConfig' => [
        'disabled' => null
    ]
  ],
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'addonsConfig' => [
    'cloudRunConfig' => [
        'disabled' => null,
        'loadBalancerType' => ''
    ],
    'configConnectorConfig' => [
        'enabled' => null
    ],
    'dnsCacheConfig' => [
        'enabled' => null
    ],
    'gcePersistentDiskCsiDriverConfig' => [
        'enabled' => null
    ],
    'gcpFilestoreCsiDriverConfig' => [
        'enabled' => null
    ],
    'gkeBackupAgentConfig' => [
        'enabled' => null
    ],
    'horizontalPodAutoscaling' => [
        'disabled' => null
    ],
    'httpLoadBalancing' => [
        'disabled' => null
    ],
    'istioConfig' => [
        'auth' => '',
        'disabled' => null
    ],
    'kalmConfig' => [
        'enabled' => null
    ],
    'kubernetesDashboard' => [
        'disabled' => null
    ],
    'networkPolicyConfig' => [
        'disabled' => null
    ]
  ],
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons"

payload = {
    "addonsConfig": {
        "cloudRunConfig": {
            "disabled": False,
            "loadBalancerType": ""
        },
        "configConnectorConfig": { "enabled": False },
        "dnsCacheConfig": { "enabled": False },
        "gcePersistentDiskCsiDriverConfig": { "enabled": False },
        "gcpFilestoreCsiDriverConfig": { "enabled": False },
        "gkeBackupAgentConfig": { "enabled": False },
        "horizontalPodAutoscaling": { "disabled": False },
        "httpLoadBalancing": { "disabled": False },
        "istioConfig": {
            "auth": "",
            "disabled": False
        },
        "kalmConfig": { "enabled": False },
        "kubernetesDashboard": { "disabled": False },
        "networkPolicyConfig": { "disabled": False }
    },
    "clusterId": "",
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons"

payload <- "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons")

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  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons') do |req|
  req.body = "{\n  \"addonsConfig\": {\n    \"cloudRunConfig\": {\n      \"disabled\": false,\n      \"loadBalancerType\": \"\"\n    },\n    \"configConnectorConfig\": {\n      \"enabled\": false\n    },\n    \"dnsCacheConfig\": {\n      \"enabled\": false\n    },\n    \"gcePersistentDiskCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gcpFilestoreCsiDriverConfig\": {\n      \"enabled\": false\n    },\n    \"gkeBackupAgentConfig\": {\n      \"enabled\": false\n    },\n    \"horizontalPodAutoscaling\": {\n      \"disabled\": false\n    },\n    \"httpLoadBalancing\": {\n      \"disabled\": false\n    },\n    \"istioConfig\": {\n      \"auth\": \"\",\n      \"disabled\": false\n    },\n    \"kalmConfig\": {\n      \"enabled\": false\n    },\n    \"kubernetesDashboard\": {\n      \"disabled\": false\n    },\n    \"networkPolicyConfig\": {\n      \"disabled\": false\n    }\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons";

    let payload = json!({
        "addonsConfig": json!({
            "cloudRunConfig": json!({
                "disabled": false,
                "loadBalancerType": ""
            }),
            "configConnectorConfig": json!({"enabled": false}),
            "dnsCacheConfig": json!({"enabled": false}),
            "gcePersistentDiskCsiDriverConfig": json!({"enabled": false}),
            "gcpFilestoreCsiDriverConfig": json!({"enabled": false}),
            "gkeBackupAgentConfig": json!({"enabled": false}),
            "horizontalPodAutoscaling": json!({"disabled": false}),
            "httpLoadBalancing": json!({"disabled": false}),
            "istioConfig": json!({
                "auth": "",
                "disabled": false
            }),
            "kalmConfig": json!({"enabled": false}),
            "kubernetesDashboard": json!({"disabled": false}),
            "networkPolicyConfig": json!({"disabled": false})
        }),
        "clusterId": "",
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons \
  --header 'content-type: application/json' \
  --data '{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "addonsConfig": {
    "cloudRunConfig": {
      "disabled": false,
      "loadBalancerType": ""
    },
    "configConnectorConfig": {
      "enabled": false
    },
    "dnsCacheConfig": {
      "enabled": false
    },
    "gcePersistentDiskCsiDriverConfig": {
      "enabled": false
    },
    "gcpFilestoreCsiDriverConfig": {
      "enabled": false
    },
    "gkeBackupAgentConfig": {
      "enabled": false
    },
    "horizontalPodAutoscaling": {
      "disabled": false
    },
    "httpLoadBalancing": {
      "disabled": false
    },
    "istioConfig": {
      "auth": "",
      "disabled": false
    },
    "kalmConfig": {
      "enabled": false
    },
    "kubernetesDashboard": {
      "disabled": false
    },
    "networkPolicyConfig": {
      "disabled": false
    }
  },
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "addonsConfig": {\n    "cloudRunConfig": {\n      "disabled": false,\n      "loadBalancerType": ""\n    },\n    "configConnectorConfig": {\n      "enabled": false\n    },\n    "dnsCacheConfig": {\n      "enabled": false\n    },\n    "gcePersistentDiskCsiDriverConfig": {\n      "enabled": false\n    },\n    "gcpFilestoreCsiDriverConfig": {\n      "enabled": false\n    },\n    "gkeBackupAgentConfig": {\n      "enabled": false\n    },\n    "horizontalPodAutoscaling": {\n      "disabled": false\n    },\n    "httpLoadBalancing": {\n      "disabled": false\n    },\n    "istioConfig": {\n      "auth": "",\n      "disabled": false\n    },\n    "kalmConfig": {\n      "enabled": false\n    },\n    "kubernetesDashboard": {\n      "disabled": false\n    },\n    "networkPolicyConfig": {\n      "disabled": false\n    }\n  },\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "addonsConfig": [
    "cloudRunConfig": [
      "disabled": false,
      "loadBalancerType": ""
    ],
    "configConnectorConfig": ["enabled": false],
    "dnsCacheConfig": ["enabled": false],
    "gcePersistentDiskCsiDriverConfig": ["enabled": false],
    "gcpFilestoreCsiDriverConfig": ["enabled": false],
    "gkeBackupAgentConfig": ["enabled": false],
    "horizontalPodAutoscaling": ["disabled": false],
    "httpLoadBalancing": ["disabled": false],
    "istioConfig": [
      "auth": "",
      "disabled": false
    ],
    "kalmConfig": ["enabled": false],
    "kubernetesDashboard": ["disabled": false],
    "networkPolicyConfig": ["disabled": false]
  ],
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/addons")! 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 container.projects.zones.clusters.completeIpRotation
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation");

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation" {:content-type :json
                                                                                                                           :form-params {:clusterId ""
                                                                                                                                         :name ""
                                                                                                                                         :projectId ""
                                                                                                                                         :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 68

{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  name: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation',
  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({clusterId: '', name: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', name: '', projectId: '', zone: ''},
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation",
  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([
    'clusterId' => '',
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation', [
  'body' => '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation"

payload = {
    "clusterId": "",
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation"

payload <- "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation")

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation";

    let payload = json!({
        "clusterId": "",
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:completeIpRotation")! 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 container.projects.zones.clusters.create
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters
QUERY PARAMS

projectId
zone
BODY json

{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters");

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  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters" {:content-type :json
                                                                                             :form-params {:cluster {:addonsConfig {:cloudRunConfig {:disabled false
                                                                                                                                                     :loadBalancerType ""}
                                                                                                                                    :configConnectorConfig {:enabled false}
                                                                                                                                    :dnsCacheConfig {:enabled false}
                                                                                                                                    :gcePersistentDiskCsiDriverConfig {:enabled false}
                                                                                                                                    :gcpFilestoreCsiDriverConfig {:enabled false}
                                                                                                                                    :gkeBackupAgentConfig {:enabled false}
                                                                                                                                    :horizontalPodAutoscaling {:disabled false}
                                                                                                                                    :httpLoadBalancing {:disabled false}
                                                                                                                                    :istioConfig {:auth ""
                                                                                                                                                  :disabled false}
                                                                                                                                    :kalmConfig {:enabled false}
                                                                                                                                    :kubernetesDashboard {:disabled false}
                                                                                                                                    :networkPolicyConfig {:disabled false}}
                                                                                                                     :authenticatorGroupsConfig {:enabled false
                                                                                                                                                 :securityGroup ""}
                                                                                                                     :autopilot {:enabled false}
                                                                                                                     :autoscaling {:autoprovisioningLocations []
                                                                                                                                   :autoprovisioningNodePoolDefaults {:bootDiskKmsKey ""
                                                                                                                                                                      :diskSizeGb 0
                                                                                                                                                                      :diskType ""
                                                                                                                                                                      :imageType ""
                                                                                                                                                                      :management {:autoRepair false
                                                                                                                                                                                   :autoUpgrade false
                                                                                                                                                                                   :upgradeOptions {:autoUpgradeStartTime ""
                                                                                                                                                                                                    :description ""}}
                                                                                                                                                                      :minCpuPlatform ""
                                                                                                                                                                      :oauthScopes []
                                                                                                                                                                      :serviceAccount ""
                                                                                                                                                                      :shieldedInstanceConfig {:enableIntegrityMonitoring false
                                                                                                                                                                                               :enableSecureBoot false}
                                                                                                                                                                      :upgradeSettings {:blueGreenSettings {:nodePoolSoakDuration ""
                                                                                                                                                                                                            :standardRolloutPolicy {:batchNodeCount 0
                                                                                                                                                                                                                                    :batchPercentage ""
                                                                                                                                                                                                                                    :batchSoakDuration ""}}
                                                                                                                                                                                        :maxSurge 0
                                                                                                                                                                                        :maxUnavailable 0
                                                                                                                                                                                        :strategy ""}}
                                                                                                                                   :autoscalingProfile ""
                                                                                                                                   :enableNodeAutoprovisioning false
                                                                                                                                   :resourceLimits [{:maximum ""
                                                                                                                                                     :minimum ""
                                                                                                                                                     :resourceType ""}]}
                                                                                                                     :binaryAuthorization {:enabled false
                                                                                                                                           :evaluationMode ""}
                                                                                                                     :clusterIpv4Cidr ""
                                                                                                                     :clusterTelemetry {:type ""}
                                                                                                                     :conditions [{:canonicalCode ""
                                                                                                                                   :code ""
                                                                                                                                   :message ""}]
                                                                                                                     :confidentialNodes {:enabled false}
                                                                                                                     :costManagementConfig {:enabled false}
                                                                                                                     :createTime ""
                                                                                                                     :currentMasterVersion ""
                                                                                                                     :currentNodeCount 0
                                                                                                                     :currentNodeVersion ""
                                                                                                                     :databaseEncryption {:keyName ""
                                                                                                                                          :state ""}
                                                                                                                     :defaultMaxPodsConstraint {:maxPodsPerNode ""}
                                                                                                                     :description ""
                                                                                                                     :enableKubernetesAlpha false
                                                                                                                     :enableTpu false
                                                                                                                     :endpoint ""
                                                                                                                     :etag ""
                                                                                                                     :expireTime ""
                                                                                                                     :fleet {:membership ""
                                                                                                                             :preRegistered false
                                                                                                                             :project ""}
                                                                                                                     :id ""
                                                                                                                     :identityServiceConfig {:enabled false}
                                                                                                                     :initialClusterVersion ""
                                                                                                                     :initialNodeCount 0
                                                                                                                     :instanceGroupUrls []
                                                                                                                     :ipAllocationPolicy {:additionalPodRangesConfig {:podRangeNames []}
                                                                                                                                          :allowRouteOverlap false
                                                                                                                                          :clusterIpv4Cidr ""
                                                                                                                                          :clusterIpv4CidrBlock ""
                                                                                                                                          :clusterSecondaryRangeName ""
                                                                                                                                          :createSubnetwork false
                                                                                                                                          :ipv6AccessType ""
                                                                                                                                          :nodeIpv4Cidr ""
                                                                                                                                          :nodeIpv4CidrBlock ""
                                                                                                                                          :podCidrOverprovisionConfig {:disable false}
                                                                                                                                          :servicesIpv4Cidr ""
                                                                                                                                          :servicesIpv4CidrBlock ""
                                                                                                                                          :servicesIpv6CidrBlock ""
                                                                                                                                          :servicesSecondaryRangeName ""
                                                                                                                                          :stackType ""
                                                                                                                                          :subnetIpv6CidrBlock ""
                                                                                                                                          :subnetworkName ""
                                                                                                                                          :tpuIpv4CidrBlock ""
                                                                                                                                          :useIpAliases false
                                                                                                                                          :useRoutes false}
                                                                                                                     :labelFingerprint ""
                                                                                                                     :legacyAbac {:enabled false}
                                                                                                                     :location ""
                                                                                                                     :locations []
                                                                                                                     :loggingConfig {:componentConfig {:enableComponents []}}
                                                                                                                     :loggingService ""
                                                                                                                     :maintenancePolicy {:resourceVersion ""
                                                                                                                                         :window {:dailyMaintenanceWindow {:duration ""
                                                                                                                                                                           :startTime ""}
                                                                                                                                                  :maintenanceExclusions {}
                                                                                                                                                  :recurringWindow {:recurrence ""
                                                                                                                                                                    :window {:endTime ""
                                                                                                                                                                             :maintenanceExclusionOptions {:scope ""}
                                                                                                                                                                             :startTime ""}}}}
                                                                                                                     :master {}
                                                                                                                     :masterAuth {:clientCertificate ""
                                                                                                                                  :clientCertificateConfig {:issueClientCertificate false}
                                                                                                                                  :clientKey ""
                                                                                                                                  :clusterCaCertificate ""
                                                                                                                                  :password ""
                                                                                                                                  :username ""}
                                                                                                                     :masterAuthorizedNetworksConfig {:cidrBlocks [{:cidrBlock ""
                                                                                                                                                                    :displayName ""}]
                                                                                                                                                      :enabled false
                                                                                                                                                      :gcpPublicCidrsAccessEnabled false}
                                                                                                                     :masterIpv4CidrBlock ""
                                                                                                                     :meshCertificates {:enableCertificates false}
                                                                                                                     :monitoringConfig {:componentConfig {:enableComponents []}
                                                                                                                                        :managedPrometheusConfig {:enabled false}}
                                                                                                                     :monitoringService ""
                                                                                                                     :name ""
                                                                                                                     :network ""
                                                                                                                     :networkConfig {:datapathProvider ""
                                                                                                                                     :defaultSnatStatus {:disabled false}
                                                                                                                                     :dnsConfig {:clusterDns ""
                                                                                                                                                 :clusterDnsDomain ""
                                                                                                                                                 :clusterDnsScope ""}
                                                                                                                                     :enableIntraNodeVisibility false
                                                                                                                                     :enableL4ilbSubsetting false
                                                                                                                                     :gatewayApiConfig {:channel ""}
                                                                                                                                     :network ""
                                                                                                                                     :privateIpv6GoogleAccess ""
                                                                                                                                     :serviceExternalIpsConfig {:enabled false}
                                                                                                                                     :subnetwork ""}
                                                                                                                     :networkPolicy {:enabled false
                                                                                                                                     :provider ""}
                                                                                                                     :nodeConfig {:accelerators [{:acceleratorCount ""
                                                                                                                                                  :acceleratorType ""
                                                                                                                                                  :gpuPartitionSize ""
                                                                                                                                                  :gpuSharingConfig {:gpuSharingStrategy ""
                                                                                                                                                                     :maxSharedClientsPerGpu ""}
                                                                                                                                                  :maxTimeSharedClientsPerGpu ""}]
                                                                                                                                  :advancedMachineFeatures {:threadsPerCore ""}
                                                                                                                                  :bootDiskKmsKey ""
                                                                                                                                  :confidentialNodes {}
                                                                                                                                  :diskSizeGb 0
                                                                                                                                  :diskType ""
                                                                                                                                  :ephemeralStorageConfig {:localSsdCount 0}
                                                                                                                                  :ephemeralStorageLocalSsdConfig {:localSsdCount 0}
                                                                                                                                  :fastSocket {:enabled false}
                                                                                                                                  :gcfsConfig {:enabled false}
                                                                                                                                  :gvnic {:enabled false}
                                                                                                                                  :imageType ""
                                                                                                                                  :kubeletConfig {:cpuCfsQuota false
                                                                                                                                                  :cpuCfsQuotaPeriod ""
                                                                                                                                                  :cpuManagerPolicy ""
                                                                                                                                                  :podPidsLimit ""}
                                                                                                                                  :labels {}
                                                                                                                                  :linuxNodeConfig {:cgroupMode ""
                                                                                                                                                    :sysctls {}}
                                                                                                                                  :localNvmeSsdBlockConfig {:localSsdCount 0}
                                                                                                                                  :localSsdCount 0
                                                                                                                                  :loggingConfig {:variantConfig {:variant ""}}
                                                                                                                                  :machineType ""
                                                                                                                                  :metadata {}
                                                                                                                                  :minCpuPlatform ""
                                                                                                                                  :nodeGroup ""
                                                                                                                                  :oauthScopes []
                                                                                                                                  :preemptible false
                                                                                                                                  :reservationAffinity {:consumeReservationType ""
                                                                                                                                                        :key ""
                                                                                                                                                        :values []}
                                                                                                                                  :resourceLabels {}
                                                                                                                                  :sandboxConfig {:sandboxType ""
                                                                                                                                                  :type ""}
                                                                                                                                  :serviceAccount ""
                                                                                                                                  :shieldedInstanceConfig {}
                                                                                                                                  :spot false
                                                                                                                                  :tags []
                                                                                                                                  :taints [{:effect ""
                                                                                                                                            :key ""
                                                                                                                                            :value ""}]
                                                                                                                                  :windowsNodeConfig {:osVersion ""}
                                                                                                                                  :workloadMetadataConfig {:mode ""
                                                                                                                                                           :nodeMetadata ""}}
                                                                                                                     :nodeIpv4CidrSize 0
                                                                                                                     :nodePoolAutoConfig {:networkTags {:tags []}}
                                                                                                                     :nodePoolDefaults {:nodeConfigDefaults {:gcfsConfig {}
                                                                                                                                                             :loggingConfig {}}}
                                                                                                                     :nodePools [{:autoscaling {:autoprovisioned false
                                                                                                                                                :enabled false
                                                                                                                                                :locationPolicy ""
                                                                                                                                                :maxNodeCount 0
                                                                                                                                                :minNodeCount 0
                                                                                                                                                :totalMaxNodeCount 0
                                                                                                                                                :totalMinNodeCount 0}
                                                                                                                                  :conditions [{}]
                                                                                                                                  :config {}
                                                                                                                                  :etag ""
                                                                                                                                  :initialNodeCount 0
                                                                                                                                  :instanceGroupUrls []
                                                                                                                                  :locations []
                                                                                                                                  :management {}
                                                                                                                                  :maxPodsConstraint {}
                                                                                                                                  :name ""
                                                                                                                                  :networkConfig {:createPodRange false
                                                                                                                                                  :enablePrivateNodes false
                                                                                                                                                  :networkPerformanceConfig {:externalIpEgressBandwidthTier ""
                                                                                                                                                                             :totalEgressBandwidthTier ""}
                                                                                                                                                  :podCidrOverprovisionConfig {}
                                                                                                                                                  :podIpv4CidrBlock ""
                                                                                                                                                  :podRange ""}
                                                                                                                                  :placementPolicy {:type ""}
                                                                                                                                  :podIpv4CidrSize 0
                                                                                                                                  :selfLink ""
                                                                                                                                  :status ""
                                                                                                                                  :statusMessage ""
                                                                                                                                  :updateInfo {:blueGreenInfo {:blueInstanceGroupUrls []
                                                                                                                                                               :bluePoolDeletionStartTime ""
                                                                                                                                                               :greenInstanceGroupUrls []
                                                                                                                                                               :greenPoolVersion ""
                                                                                                                                                               :phase ""}}
                                                                                                                                  :upgradeSettings {}
                                                                                                                                  :version ""}]
                                                                                                                     :notificationConfig {:pubsub {:enabled false
                                                                                                                                                   :filter {:eventType []}
                                                                                                                                                   :topic ""}}
                                                                                                                     :podSecurityPolicyConfig {:enabled false}
                                                                                                                     :privateCluster false
                                                                                                                     :privateClusterConfig {:enablePrivateEndpoint false
                                                                                                                                            :enablePrivateNodes false
                                                                                                                                            :masterGlobalAccessConfig {:enabled false}
                                                                                                                                            :masterIpv4CidrBlock ""
                                                                                                                                            :peeringName ""
                                                                                                                                            :privateEndpoint ""
                                                                                                                                            :privateEndpointSubnetwork ""
                                                                                                                                            :publicEndpoint ""}
                                                                                                                     :protectConfig {:workloadConfig {:auditMode ""}
                                                                                                                                     :workloadVulnerabilityMode ""}
                                                                                                                     :releaseChannel {:channel ""}
                                                                                                                     :resourceLabels {}
                                                                                                                     :resourceUsageExportConfig {:bigqueryDestination {:datasetId ""}
                                                                                                                                                 :consumptionMeteringConfig {:enabled false}
                                                                                                                                                 :enableNetworkEgressMetering false}
                                                                                                                     :selfLink ""
                                                                                                                     :servicesIpv4Cidr ""
                                                                                                                     :shieldedNodes {:enabled false}
                                                                                                                     :status ""
                                                                                                                     :statusMessage ""
                                                                                                                     :subnetwork ""
                                                                                                                     :tpuConfig {:enabled false
                                                                                                                                 :ipv4CidrBlock ""
                                                                                                                                 :useServiceNetworking false}
                                                                                                                     :tpuIpv4CidrBlock ""
                                                                                                                     :verticalPodAutoscaling {:enabled false}
                                                                                                                     :workloadAltsConfig {:enableAlts false}
                                                                                                                     :workloadCertificates {:enableCertificates false}
                                                                                                                     :workloadIdentityConfig {:identityNamespace ""
                                                                                                                                              :identityProvider ""
                                                                                                                                              :workloadPool ""}
                                                                                                                     :zone ""}
                                                                                                           :parent ""
                                                                                                           :projectId ""
                                                                                                           :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters"),
    Content = new StringContent("{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters"

	payload := strings.NewReader("{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 11569

{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters")
  .header("content-type", "application/json")
  .body("{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  cluster: {
    addonsConfig: {
      cloudRunConfig: {
        disabled: false,
        loadBalancerType: ''
      },
      configConnectorConfig: {
        enabled: false
      },
      dnsCacheConfig: {
        enabled: false
      },
      gcePersistentDiskCsiDriverConfig: {
        enabled: false
      },
      gcpFilestoreCsiDriverConfig: {
        enabled: false
      },
      gkeBackupAgentConfig: {
        enabled: false
      },
      horizontalPodAutoscaling: {
        disabled: false
      },
      httpLoadBalancing: {
        disabled: false
      },
      istioConfig: {
        auth: '',
        disabled: false
      },
      kalmConfig: {
        enabled: false
      },
      kubernetesDashboard: {
        disabled: false
      },
      networkPolicyConfig: {
        disabled: false
      }
    },
    authenticatorGroupsConfig: {
      enabled: false,
      securityGroup: ''
    },
    autopilot: {
      enabled: false
    },
    autoscaling: {
      autoprovisioningLocations: [],
      autoprovisioningNodePoolDefaults: {
        bootDiskKmsKey: '',
        diskSizeGb: 0,
        diskType: '',
        imageType: '',
        management: {
          autoRepair: false,
          autoUpgrade: false,
          upgradeOptions: {
            autoUpgradeStartTime: '',
            description: ''
          }
        },
        minCpuPlatform: '',
        oauthScopes: [],
        serviceAccount: '',
        shieldedInstanceConfig: {
          enableIntegrityMonitoring: false,
          enableSecureBoot: false
        },
        upgradeSettings: {
          blueGreenSettings: {
            nodePoolSoakDuration: '',
            standardRolloutPolicy: {
              batchNodeCount: 0,
              batchPercentage: '',
              batchSoakDuration: ''
            }
          },
          maxSurge: 0,
          maxUnavailable: 0,
          strategy: ''
        }
      },
      autoscalingProfile: '',
      enableNodeAutoprovisioning: false,
      resourceLimits: [
        {
          maximum: '',
          minimum: '',
          resourceType: ''
        }
      ]
    },
    binaryAuthorization: {
      enabled: false,
      evaluationMode: ''
    },
    clusterIpv4Cidr: '',
    clusterTelemetry: {
      type: ''
    },
    conditions: [
      {
        canonicalCode: '',
        code: '',
        message: ''
      }
    ],
    confidentialNodes: {
      enabled: false
    },
    costManagementConfig: {
      enabled: false
    },
    createTime: '',
    currentMasterVersion: '',
    currentNodeCount: 0,
    currentNodeVersion: '',
    databaseEncryption: {
      keyName: '',
      state: ''
    },
    defaultMaxPodsConstraint: {
      maxPodsPerNode: ''
    },
    description: '',
    enableKubernetesAlpha: false,
    enableTpu: false,
    endpoint: '',
    etag: '',
    expireTime: '',
    fleet: {
      membership: '',
      preRegistered: false,
      project: ''
    },
    id: '',
    identityServiceConfig: {
      enabled: false
    },
    initialClusterVersion: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    ipAllocationPolicy: {
      additionalPodRangesConfig: {
        podRangeNames: []
      },
      allowRouteOverlap: false,
      clusterIpv4Cidr: '',
      clusterIpv4CidrBlock: '',
      clusterSecondaryRangeName: '',
      createSubnetwork: false,
      ipv6AccessType: '',
      nodeIpv4Cidr: '',
      nodeIpv4CidrBlock: '',
      podCidrOverprovisionConfig: {
        disable: false
      },
      servicesIpv4Cidr: '',
      servicesIpv4CidrBlock: '',
      servicesIpv6CidrBlock: '',
      servicesSecondaryRangeName: '',
      stackType: '',
      subnetIpv6CidrBlock: '',
      subnetworkName: '',
      tpuIpv4CidrBlock: '',
      useIpAliases: false,
      useRoutes: false
    },
    labelFingerprint: '',
    legacyAbac: {
      enabled: false
    },
    location: '',
    locations: [],
    loggingConfig: {
      componentConfig: {
        enableComponents: []
      }
    },
    loggingService: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {
          duration: '',
          startTime: ''
        },
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {
            endTime: '',
            maintenanceExclusionOptions: {
              scope: ''
            },
            startTime: ''
          }
        }
      }
    },
    master: {},
    masterAuth: {
      clientCertificate: '',
      clientCertificateConfig: {
        issueClientCertificate: false
      },
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    masterAuthorizedNetworksConfig: {
      cidrBlocks: [
        {
          cidrBlock: '',
          displayName: ''
        }
      ],
      enabled: false,
      gcpPublicCidrsAccessEnabled: false
    },
    masterIpv4CidrBlock: '',
    meshCertificates: {
      enableCertificates: false
    },
    monitoringConfig: {
      componentConfig: {
        enableComponents: []
      },
      managedPrometheusConfig: {
        enabled: false
      }
    },
    monitoringService: '',
    name: '',
    network: '',
    networkConfig: {
      datapathProvider: '',
      defaultSnatStatus: {
        disabled: false
      },
      dnsConfig: {
        clusterDns: '',
        clusterDnsDomain: '',
        clusterDnsScope: ''
      },
      enableIntraNodeVisibility: false,
      enableL4ilbSubsetting: false,
      gatewayApiConfig: {
        channel: ''
      },
      network: '',
      privateIpv6GoogleAccess: '',
      serviceExternalIpsConfig: {
        enabled: false
      },
      subnetwork: ''
    },
    networkPolicy: {
      enabled: false,
      provider: ''
    },
    nodeConfig: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {
            gpuSharingStrategy: '',
            maxSharedClientsPerGpu: ''
          },
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {
        threadsPerCore: ''
      },
      bootDiskKmsKey: '',
      confidentialNodes: {},
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {
        localSsdCount: 0
      },
      ephemeralStorageLocalSsdConfig: {
        localSsdCount: 0
      },
      fastSocket: {
        enabled: false
      },
      gcfsConfig: {
        enabled: false
      },
      gvnic: {
        enabled: false
      },
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {
        cgroupMode: '',
        sysctls: {}
      },
      localNvmeSsdBlockConfig: {
        localSsdCount: 0
      },
      localSsdCount: 0,
      loggingConfig: {
        variantConfig: {
          variant: ''
        }
      },
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {
        consumeReservationType: '',
        key: '',
        values: []
      },
      resourceLabels: {},
      sandboxConfig: {
        sandboxType: '',
        type: ''
      },
      serviceAccount: '',
      shieldedInstanceConfig: {},
      spot: false,
      tags: [],
      taints: [
        {
          effect: '',
          key: '',
          value: ''
        }
      ],
      windowsNodeConfig: {
        osVersion: ''
      },
      workloadMetadataConfig: {
        mode: '',
        nodeMetadata: ''
      }
    },
    nodeIpv4CidrSize: 0,
    nodePoolAutoConfig: {
      networkTags: {
        tags: []
      }
    },
    nodePoolDefaults: {
      nodeConfigDefaults: {
        gcfsConfig: {},
        loggingConfig: {}
      }
    },
    nodePools: [
      {
        autoscaling: {
          autoprovisioned: false,
          enabled: false,
          locationPolicy: '',
          maxNodeCount: 0,
          minNodeCount: 0,
          totalMaxNodeCount: 0,
          totalMinNodeCount: 0
        },
        conditions: [
          {}
        ],
        config: {},
        etag: '',
        initialNodeCount: 0,
        instanceGroupUrls: [],
        locations: [],
        management: {},
        maxPodsConstraint: {},
        name: '',
        networkConfig: {
          createPodRange: false,
          enablePrivateNodes: false,
          networkPerformanceConfig: {
            externalIpEgressBandwidthTier: '',
            totalEgressBandwidthTier: ''
          },
          podCidrOverprovisionConfig: {},
          podIpv4CidrBlock: '',
          podRange: ''
        },
        placementPolicy: {
          type: ''
        },
        podIpv4CidrSize: 0,
        selfLink: '',
        status: '',
        statusMessage: '',
        updateInfo: {
          blueGreenInfo: {
            blueInstanceGroupUrls: [],
            bluePoolDeletionStartTime: '',
            greenInstanceGroupUrls: [],
            greenPoolVersion: '',
            phase: ''
          }
        },
        upgradeSettings: {},
        version: ''
      }
    ],
    notificationConfig: {
      pubsub: {
        enabled: false,
        filter: {
          eventType: []
        },
        topic: ''
      }
    },
    podSecurityPolicyConfig: {
      enabled: false
    },
    privateCluster: false,
    privateClusterConfig: {
      enablePrivateEndpoint: false,
      enablePrivateNodes: false,
      masterGlobalAccessConfig: {
        enabled: false
      },
      masterIpv4CidrBlock: '',
      peeringName: '',
      privateEndpoint: '',
      privateEndpointSubnetwork: '',
      publicEndpoint: ''
    },
    protectConfig: {
      workloadConfig: {
        auditMode: ''
      },
      workloadVulnerabilityMode: ''
    },
    releaseChannel: {
      channel: ''
    },
    resourceLabels: {},
    resourceUsageExportConfig: {
      bigqueryDestination: {
        datasetId: ''
      },
      consumptionMeteringConfig: {
        enabled: false
      },
      enableNetworkEgressMetering: false
    },
    selfLink: '',
    servicesIpv4Cidr: '',
    shieldedNodes: {
      enabled: false
    },
    status: '',
    statusMessage: '',
    subnetwork: '',
    tpuConfig: {
      enabled: false,
      ipv4CidrBlock: '',
      useServiceNetworking: false
    },
    tpuIpv4CidrBlock: '',
    verticalPodAutoscaling: {
      enabled: false
    },
    workloadAltsConfig: {
      enableAlts: false
    },
    workloadCertificates: {
      enableCertificates: false
    },
    workloadIdentityConfig: {
      identityNamespace: '',
      identityProvider: '',
      workloadPool: ''
    },
    zone: ''
  },
  parent: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters',
  headers: {'content-type': 'application/json'},
  data: {
    cluster: {
      addonsConfig: {
        cloudRunConfig: {disabled: false, loadBalancerType: ''},
        configConnectorConfig: {enabled: false},
        dnsCacheConfig: {enabled: false},
        gcePersistentDiskCsiDriverConfig: {enabled: false},
        gcpFilestoreCsiDriverConfig: {enabled: false},
        gkeBackupAgentConfig: {enabled: false},
        horizontalPodAutoscaling: {disabled: false},
        httpLoadBalancing: {disabled: false},
        istioConfig: {auth: '', disabled: false},
        kalmConfig: {enabled: false},
        kubernetesDashboard: {disabled: false},
        networkPolicyConfig: {disabled: false}
      },
      authenticatorGroupsConfig: {enabled: false, securityGroup: ''},
      autopilot: {enabled: false},
      autoscaling: {
        autoprovisioningLocations: [],
        autoprovisioningNodePoolDefaults: {
          bootDiskKmsKey: '',
          diskSizeGb: 0,
          diskType: '',
          imageType: '',
          management: {
            autoRepair: false,
            autoUpgrade: false,
            upgradeOptions: {autoUpgradeStartTime: '', description: ''}
          },
          minCpuPlatform: '',
          oauthScopes: [],
          serviceAccount: '',
          shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
          upgradeSettings: {
            blueGreenSettings: {
              nodePoolSoakDuration: '',
              standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
            },
            maxSurge: 0,
            maxUnavailable: 0,
            strategy: ''
          }
        },
        autoscalingProfile: '',
        enableNodeAutoprovisioning: false,
        resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
      },
      binaryAuthorization: {enabled: false, evaluationMode: ''},
      clusterIpv4Cidr: '',
      clusterTelemetry: {type: ''},
      conditions: [{canonicalCode: '', code: '', message: ''}],
      confidentialNodes: {enabled: false},
      costManagementConfig: {enabled: false},
      createTime: '',
      currentMasterVersion: '',
      currentNodeCount: 0,
      currentNodeVersion: '',
      databaseEncryption: {keyName: '', state: ''},
      defaultMaxPodsConstraint: {maxPodsPerNode: ''},
      description: '',
      enableKubernetesAlpha: false,
      enableTpu: false,
      endpoint: '',
      etag: '',
      expireTime: '',
      fleet: {membership: '', preRegistered: false, project: ''},
      id: '',
      identityServiceConfig: {enabled: false},
      initialClusterVersion: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      ipAllocationPolicy: {
        additionalPodRangesConfig: {podRangeNames: []},
        allowRouteOverlap: false,
        clusterIpv4Cidr: '',
        clusterIpv4CidrBlock: '',
        clusterSecondaryRangeName: '',
        createSubnetwork: false,
        ipv6AccessType: '',
        nodeIpv4Cidr: '',
        nodeIpv4CidrBlock: '',
        podCidrOverprovisionConfig: {disable: false},
        servicesIpv4Cidr: '',
        servicesIpv4CidrBlock: '',
        servicesIpv6CidrBlock: '',
        servicesSecondaryRangeName: '',
        stackType: '',
        subnetIpv6CidrBlock: '',
        subnetworkName: '',
        tpuIpv4CidrBlock: '',
        useIpAliases: false,
        useRoutes: false
      },
      labelFingerprint: '',
      legacyAbac: {enabled: false},
      location: '',
      locations: [],
      loggingConfig: {componentConfig: {enableComponents: []}},
      loggingService: '',
      maintenancePolicy: {
        resourceVersion: '',
        window: {
          dailyMaintenanceWindow: {duration: '', startTime: ''},
          maintenanceExclusions: {},
          recurringWindow: {
            recurrence: '',
            window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
          }
        }
      },
      master: {},
      masterAuth: {
        clientCertificate: '',
        clientCertificateConfig: {issueClientCertificate: false},
        clientKey: '',
        clusterCaCertificate: '',
        password: '',
        username: ''
      },
      masterAuthorizedNetworksConfig: {
        cidrBlocks: [{cidrBlock: '', displayName: ''}],
        enabled: false,
        gcpPublicCidrsAccessEnabled: false
      },
      masterIpv4CidrBlock: '',
      meshCertificates: {enableCertificates: false},
      monitoringConfig: {
        componentConfig: {enableComponents: []},
        managedPrometheusConfig: {enabled: false}
      },
      monitoringService: '',
      name: '',
      network: '',
      networkConfig: {
        datapathProvider: '',
        defaultSnatStatus: {disabled: false},
        dnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
        enableIntraNodeVisibility: false,
        enableL4ilbSubsetting: false,
        gatewayApiConfig: {channel: ''},
        network: '',
        privateIpv6GoogleAccess: '',
        serviceExternalIpsConfig: {enabled: false},
        subnetwork: ''
      },
      networkPolicy: {enabled: false, provider: ''},
      nodeConfig: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      nodeIpv4CidrSize: 0,
      nodePoolAutoConfig: {networkTags: {tags: []}},
      nodePoolDefaults: {nodeConfigDefaults: {gcfsConfig: {}, loggingConfig: {}}},
      nodePools: [
        {
          autoscaling: {
            autoprovisioned: false,
            enabled: false,
            locationPolicy: '',
            maxNodeCount: 0,
            minNodeCount: 0,
            totalMaxNodeCount: 0,
            totalMinNodeCount: 0
          },
          conditions: [{}],
          config: {},
          etag: '',
          initialNodeCount: 0,
          instanceGroupUrls: [],
          locations: [],
          management: {},
          maxPodsConstraint: {},
          name: '',
          networkConfig: {
            createPodRange: false,
            enablePrivateNodes: false,
            networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
            podCidrOverprovisionConfig: {},
            podIpv4CidrBlock: '',
            podRange: ''
          },
          placementPolicy: {type: ''},
          podIpv4CidrSize: 0,
          selfLink: '',
          status: '',
          statusMessage: '',
          updateInfo: {
            blueGreenInfo: {
              blueInstanceGroupUrls: [],
              bluePoolDeletionStartTime: '',
              greenInstanceGroupUrls: [],
              greenPoolVersion: '',
              phase: ''
            }
          },
          upgradeSettings: {},
          version: ''
        }
      ],
      notificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
      podSecurityPolicyConfig: {enabled: false},
      privateCluster: false,
      privateClusterConfig: {
        enablePrivateEndpoint: false,
        enablePrivateNodes: false,
        masterGlobalAccessConfig: {enabled: false},
        masterIpv4CidrBlock: '',
        peeringName: '',
        privateEndpoint: '',
        privateEndpointSubnetwork: '',
        publicEndpoint: ''
      },
      protectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
      releaseChannel: {channel: ''},
      resourceLabels: {},
      resourceUsageExportConfig: {
        bigqueryDestination: {datasetId: ''},
        consumptionMeteringConfig: {enabled: false},
        enableNetworkEgressMetering: false
      },
      selfLink: '',
      servicesIpv4Cidr: '',
      shieldedNodes: {enabled: false},
      status: '',
      statusMessage: '',
      subnetwork: '',
      tpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
      tpuIpv4CidrBlock: '',
      verticalPodAutoscaling: {enabled: false},
      workloadAltsConfig: {enableAlts: false},
      workloadCertificates: {enableCertificates: false},
      workloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
      zone: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cluster":{"addonsConfig":{"cloudRunConfig":{"disabled":false,"loadBalancerType":""},"configConnectorConfig":{"enabled":false},"dnsCacheConfig":{"enabled":false},"gcePersistentDiskCsiDriverConfig":{"enabled":false},"gcpFilestoreCsiDriverConfig":{"enabled":false},"gkeBackupAgentConfig":{"enabled":false},"horizontalPodAutoscaling":{"disabled":false},"httpLoadBalancing":{"disabled":false},"istioConfig":{"auth":"","disabled":false},"kalmConfig":{"enabled":false},"kubernetesDashboard":{"disabled":false},"networkPolicyConfig":{"disabled":false}},"authenticatorGroupsConfig":{"enabled":false,"securityGroup":""},"autopilot":{"enabled":false},"autoscaling":{"autoprovisioningLocations":[],"autoprovisioningNodePoolDefaults":{"bootDiskKmsKey":"","diskSizeGb":0,"diskType":"","imageType":"","management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"minCpuPlatform":"","oauthScopes":[],"serviceAccount":"","shieldedInstanceConfig":{"enableIntegrityMonitoring":false,"enableSecureBoot":false},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""}},"autoscalingProfile":"","enableNodeAutoprovisioning":false,"resourceLimits":[{"maximum":"","minimum":"","resourceType":""}]},"binaryAuthorization":{"enabled":false,"evaluationMode":""},"clusterIpv4Cidr":"","clusterTelemetry":{"type":""},"conditions":[{"canonicalCode":"","code":"","message":""}],"confidentialNodes":{"enabled":false},"costManagementConfig":{"enabled":false},"createTime":"","currentMasterVersion":"","currentNodeCount":0,"currentNodeVersion":"","databaseEncryption":{"keyName":"","state":""},"defaultMaxPodsConstraint":{"maxPodsPerNode":""},"description":"","enableKubernetesAlpha":false,"enableTpu":false,"endpoint":"","etag":"","expireTime":"","fleet":{"membership":"","preRegistered":false,"project":""},"id":"","identityServiceConfig":{"enabled":false},"initialClusterVersion":"","initialNodeCount":0,"instanceGroupUrls":[],"ipAllocationPolicy":{"additionalPodRangesConfig":{"podRangeNames":[]},"allowRouteOverlap":false,"clusterIpv4Cidr":"","clusterIpv4CidrBlock":"","clusterSecondaryRangeName":"","createSubnetwork":false,"ipv6AccessType":"","nodeIpv4Cidr":"","nodeIpv4CidrBlock":"","podCidrOverprovisionConfig":{"disable":false},"servicesIpv4Cidr":"","servicesIpv4CidrBlock":"","servicesIpv6CidrBlock":"","servicesSecondaryRangeName":"","stackType":"","subnetIpv6CidrBlock":"","subnetworkName":"","tpuIpv4CidrBlock":"","useIpAliases":false,"useRoutes":false},"labelFingerprint":"","legacyAbac":{"enabled":false},"location":"","locations":[],"loggingConfig":{"componentConfig":{"enableComponents":[]}},"loggingService":"","maintenancePolicy":{"resourceVersion":"","window":{"dailyMaintenanceWindow":{"duration":"","startTime":""},"maintenanceExclusions":{},"recurringWindow":{"recurrence":"","window":{"endTime":"","maintenanceExclusionOptions":{"scope":""},"startTime":""}}}},"master":{},"masterAuth":{"clientCertificate":"","clientCertificateConfig":{"issueClientCertificate":false},"clientKey":"","clusterCaCertificate":"","password":"","username":""},"masterAuthorizedNetworksConfig":{"cidrBlocks":[{"cidrBlock":"","displayName":""}],"enabled":false,"gcpPublicCidrsAccessEnabled":false},"masterIpv4CidrBlock":"","meshCertificates":{"enableCertificates":false},"monitoringConfig":{"componentConfig":{"enableComponents":[]},"managedPrometheusConfig":{"enabled":false}},"monitoringService":"","name":"","network":"","networkConfig":{"datapathProvider":"","defaultSnatStatus":{"disabled":false},"dnsConfig":{"clusterDns":"","clusterDnsDomain":"","clusterDnsScope":""},"enableIntraNodeVisibility":false,"enableL4ilbSubsetting":false,"gatewayApiConfig":{"channel":""},"network":"","privateIpv6GoogleAccess":"","serviceExternalIpsConfig":{"enabled":false},"subnetwork":""},"networkPolicy":{"enabled":false,"provider":""},"nodeConfig":{"accelerators":[{"acceleratorCount":"","acceleratorType":"","gpuPartitionSize":"","gpuSharingConfig":{"gpuSharingStrategy":"","maxSharedClientsPerGpu":""},"maxTimeSharedClientsPerGpu":""}],"advancedMachineFeatures":{"threadsPerCore":""},"bootDiskKmsKey":"","confidentialNodes":{},"diskSizeGb":0,"diskType":"","ephemeralStorageConfig":{"localSsdCount":0},"ephemeralStorageLocalSsdConfig":{"localSsdCount":0},"fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"localNvmeSsdBlockConfig":{"localSsdCount":0},"localSsdCount":0,"loggingConfig":{"variantConfig":{"variant":""}},"machineType":"","metadata":{},"minCpuPlatform":"","nodeGroup":"","oauthScopes":[],"preemptible":false,"reservationAffinity":{"consumeReservationType":"","key":"","values":[]},"resourceLabels":{},"sandboxConfig":{"sandboxType":"","type":""},"serviceAccount":"","shieldedInstanceConfig":{},"spot":false,"tags":[],"taints":[{"effect":"","key":"","value":""}],"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""}},"nodeIpv4CidrSize":0,"nodePoolAutoConfig":{"networkTags":{"tags":[]}},"nodePoolDefaults":{"nodeConfigDefaults":{"gcfsConfig":{},"loggingConfig":{}}},"nodePools":[{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"conditions":[{}],"config":{},"etag":"","initialNodeCount":0,"instanceGroupUrls":[],"locations":[],"management":{},"maxPodsConstraint":{},"name":"","networkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{},"podIpv4CidrBlock":"","podRange":""},"placementPolicy":{"type":""},"podIpv4CidrSize":0,"selfLink":"","status":"","statusMessage":"","updateInfo":{"blueGreenInfo":{"blueInstanceGroupUrls":[],"bluePoolDeletionStartTime":"","greenInstanceGroupUrls":[],"greenPoolVersion":"","phase":""}},"upgradeSettings":{},"version":""}],"notificationConfig":{"pubsub":{"enabled":false,"filter":{"eventType":[]},"topic":""}},"podSecurityPolicyConfig":{"enabled":false},"privateCluster":false,"privateClusterConfig":{"enablePrivateEndpoint":false,"enablePrivateNodes":false,"masterGlobalAccessConfig":{"enabled":false},"masterIpv4CidrBlock":"","peeringName":"","privateEndpoint":"","privateEndpointSubnetwork":"","publicEndpoint":""},"protectConfig":{"workloadConfig":{"auditMode":""},"workloadVulnerabilityMode":""},"releaseChannel":{"channel":""},"resourceLabels":{},"resourceUsageExportConfig":{"bigqueryDestination":{"datasetId":""},"consumptionMeteringConfig":{"enabled":false},"enableNetworkEgressMetering":false},"selfLink":"","servicesIpv4Cidr":"","shieldedNodes":{"enabled":false},"status":"","statusMessage":"","subnetwork":"","tpuConfig":{"enabled":false,"ipv4CidrBlock":"","useServiceNetworking":false},"tpuIpv4CidrBlock":"","verticalPodAutoscaling":{"enabled":false},"workloadAltsConfig":{"enableAlts":false},"workloadCertificates":{"enableCertificates":false},"workloadIdentityConfig":{"identityNamespace":"","identityProvider":"","workloadPool":""},"zone":""},"parent":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "cluster": {\n    "addonsConfig": {\n      "cloudRunConfig": {\n        "disabled": false,\n        "loadBalancerType": ""\n      },\n      "configConnectorConfig": {\n        "enabled": false\n      },\n      "dnsCacheConfig": {\n        "enabled": false\n      },\n      "gcePersistentDiskCsiDriverConfig": {\n        "enabled": false\n      },\n      "gcpFilestoreCsiDriverConfig": {\n        "enabled": false\n      },\n      "gkeBackupAgentConfig": {\n        "enabled": false\n      },\n      "horizontalPodAutoscaling": {\n        "disabled": false\n      },\n      "httpLoadBalancing": {\n        "disabled": false\n      },\n      "istioConfig": {\n        "auth": "",\n        "disabled": false\n      },\n      "kalmConfig": {\n        "enabled": false\n      },\n      "kubernetesDashboard": {\n        "disabled": false\n      },\n      "networkPolicyConfig": {\n        "disabled": false\n      }\n    },\n    "authenticatorGroupsConfig": {\n      "enabled": false,\n      "securityGroup": ""\n    },\n    "autopilot": {\n      "enabled": false\n    },\n    "autoscaling": {\n      "autoprovisioningLocations": [],\n      "autoprovisioningNodePoolDefaults": {\n        "bootDiskKmsKey": "",\n        "diskSizeGb": 0,\n        "diskType": "",\n        "imageType": "",\n        "management": {\n          "autoRepair": false,\n          "autoUpgrade": false,\n          "upgradeOptions": {\n            "autoUpgradeStartTime": "",\n            "description": ""\n          }\n        },\n        "minCpuPlatform": "",\n        "oauthScopes": [],\n        "serviceAccount": "",\n        "shieldedInstanceConfig": {\n          "enableIntegrityMonitoring": false,\n          "enableSecureBoot": false\n        },\n        "upgradeSettings": {\n          "blueGreenSettings": {\n            "nodePoolSoakDuration": "",\n            "standardRolloutPolicy": {\n              "batchNodeCount": 0,\n              "batchPercentage": "",\n              "batchSoakDuration": ""\n            }\n          },\n          "maxSurge": 0,\n          "maxUnavailable": 0,\n          "strategy": ""\n        }\n      },\n      "autoscalingProfile": "",\n      "enableNodeAutoprovisioning": false,\n      "resourceLimits": [\n        {\n          "maximum": "",\n          "minimum": "",\n          "resourceType": ""\n        }\n      ]\n    },\n    "binaryAuthorization": {\n      "enabled": false,\n      "evaluationMode": ""\n    },\n    "clusterIpv4Cidr": "",\n    "clusterTelemetry": {\n      "type": ""\n    },\n    "conditions": [\n      {\n        "canonicalCode": "",\n        "code": "",\n        "message": ""\n      }\n    ],\n    "confidentialNodes": {\n      "enabled": false\n    },\n    "costManagementConfig": {\n      "enabled": false\n    },\n    "createTime": "",\n    "currentMasterVersion": "",\n    "currentNodeCount": 0,\n    "currentNodeVersion": "",\n    "databaseEncryption": {\n      "keyName": "",\n      "state": ""\n    },\n    "defaultMaxPodsConstraint": {\n      "maxPodsPerNode": ""\n    },\n    "description": "",\n    "enableKubernetesAlpha": false,\n    "enableTpu": false,\n    "endpoint": "",\n    "etag": "",\n    "expireTime": "",\n    "fleet": {\n      "membership": "",\n      "preRegistered": false,\n      "project": ""\n    },\n    "id": "",\n    "identityServiceConfig": {\n      "enabled": false\n    },\n    "initialClusterVersion": "",\n    "initialNodeCount": 0,\n    "instanceGroupUrls": [],\n    "ipAllocationPolicy": {\n      "additionalPodRangesConfig": {\n        "podRangeNames": []\n      },\n      "allowRouteOverlap": false,\n      "clusterIpv4Cidr": "",\n      "clusterIpv4CidrBlock": "",\n      "clusterSecondaryRangeName": "",\n      "createSubnetwork": false,\n      "ipv6AccessType": "",\n      "nodeIpv4Cidr": "",\n      "nodeIpv4CidrBlock": "",\n      "podCidrOverprovisionConfig": {\n        "disable": false\n      },\n      "servicesIpv4Cidr": "",\n      "servicesIpv4CidrBlock": "",\n      "servicesIpv6CidrBlock": "",\n      "servicesSecondaryRangeName": "",\n      "stackType": "",\n      "subnetIpv6CidrBlock": "",\n      "subnetworkName": "",\n      "tpuIpv4CidrBlock": "",\n      "useIpAliases": false,\n      "useRoutes": false\n    },\n    "labelFingerprint": "",\n    "legacyAbac": {\n      "enabled": false\n    },\n    "location": "",\n    "locations": [],\n    "loggingConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      }\n    },\n    "loggingService": "",\n    "maintenancePolicy": {\n      "resourceVersion": "",\n      "window": {\n        "dailyMaintenanceWindow": {\n          "duration": "",\n          "startTime": ""\n        },\n        "maintenanceExclusions": {},\n        "recurringWindow": {\n          "recurrence": "",\n          "window": {\n            "endTime": "",\n            "maintenanceExclusionOptions": {\n              "scope": ""\n            },\n            "startTime": ""\n          }\n        }\n      }\n    },\n    "master": {},\n    "masterAuth": {\n      "clientCertificate": "",\n      "clientCertificateConfig": {\n        "issueClientCertificate": false\n      },\n      "clientKey": "",\n      "clusterCaCertificate": "",\n      "password": "",\n      "username": ""\n    },\n    "masterAuthorizedNetworksConfig": {\n      "cidrBlocks": [\n        {\n          "cidrBlock": "",\n          "displayName": ""\n        }\n      ],\n      "enabled": false,\n      "gcpPublicCidrsAccessEnabled": false\n    },\n    "masterIpv4CidrBlock": "",\n    "meshCertificates": {\n      "enableCertificates": false\n    },\n    "monitoringConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      },\n      "managedPrometheusConfig": {\n        "enabled": false\n      }\n    },\n    "monitoringService": "",\n    "name": "",\n    "network": "",\n    "networkConfig": {\n      "datapathProvider": "",\n      "defaultSnatStatus": {\n        "disabled": false\n      },\n      "dnsConfig": {\n        "clusterDns": "",\n        "clusterDnsDomain": "",\n        "clusterDnsScope": ""\n      },\n      "enableIntraNodeVisibility": false,\n      "enableL4ilbSubsetting": false,\n      "gatewayApiConfig": {\n        "channel": ""\n      },\n      "network": "",\n      "privateIpv6GoogleAccess": "",\n      "serviceExternalIpsConfig": {\n        "enabled": false\n      },\n      "subnetwork": ""\n    },\n    "networkPolicy": {\n      "enabled": false,\n      "provider": ""\n    },\n    "nodeConfig": {\n      "accelerators": [\n        {\n          "acceleratorCount": "",\n          "acceleratorType": "",\n          "gpuPartitionSize": "",\n          "gpuSharingConfig": {\n            "gpuSharingStrategy": "",\n            "maxSharedClientsPerGpu": ""\n          },\n          "maxTimeSharedClientsPerGpu": ""\n        }\n      ],\n      "advancedMachineFeatures": {\n        "threadsPerCore": ""\n      },\n      "bootDiskKmsKey": "",\n      "confidentialNodes": {},\n      "diskSizeGb": 0,\n      "diskType": "",\n      "ephemeralStorageConfig": {\n        "localSsdCount": 0\n      },\n      "ephemeralStorageLocalSsdConfig": {\n        "localSsdCount": 0\n      },\n      "fastSocket": {\n        "enabled": false\n      },\n      "gcfsConfig": {\n        "enabled": false\n      },\n      "gvnic": {\n        "enabled": false\n      },\n      "imageType": "",\n      "kubeletConfig": {\n        "cpuCfsQuota": false,\n        "cpuCfsQuotaPeriod": "",\n        "cpuManagerPolicy": "",\n        "podPidsLimit": ""\n      },\n      "labels": {},\n      "linuxNodeConfig": {\n        "cgroupMode": "",\n        "sysctls": {}\n      },\n      "localNvmeSsdBlockConfig": {\n        "localSsdCount": 0\n      },\n      "localSsdCount": 0,\n      "loggingConfig": {\n        "variantConfig": {\n          "variant": ""\n        }\n      },\n      "machineType": "",\n      "metadata": {},\n      "minCpuPlatform": "",\n      "nodeGroup": "",\n      "oauthScopes": [],\n      "preemptible": false,\n      "reservationAffinity": {\n        "consumeReservationType": "",\n        "key": "",\n        "values": []\n      },\n      "resourceLabels": {},\n      "sandboxConfig": {\n        "sandboxType": "",\n        "type": ""\n      },\n      "serviceAccount": "",\n      "shieldedInstanceConfig": {},\n      "spot": false,\n      "tags": [],\n      "taints": [\n        {\n          "effect": "",\n          "key": "",\n          "value": ""\n        }\n      ],\n      "windowsNodeConfig": {\n        "osVersion": ""\n      },\n      "workloadMetadataConfig": {\n        "mode": "",\n        "nodeMetadata": ""\n      }\n    },\n    "nodeIpv4CidrSize": 0,\n    "nodePoolAutoConfig": {\n      "networkTags": {\n        "tags": []\n      }\n    },\n    "nodePoolDefaults": {\n      "nodeConfigDefaults": {\n        "gcfsConfig": {},\n        "loggingConfig": {}\n      }\n    },\n    "nodePools": [\n      {\n        "autoscaling": {\n          "autoprovisioned": false,\n          "enabled": false,\n          "locationPolicy": "",\n          "maxNodeCount": 0,\n          "minNodeCount": 0,\n          "totalMaxNodeCount": 0,\n          "totalMinNodeCount": 0\n        },\n        "conditions": [\n          {}\n        ],\n        "config": {},\n        "etag": "",\n        "initialNodeCount": 0,\n        "instanceGroupUrls": [],\n        "locations": [],\n        "management": {},\n        "maxPodsConstraint": {},\n        "name": "",\n        "networkConfig": {\n          "createPodRange": false,\n          "enablePrivateNodes": false,\n          "networkPerformanceConfig": {\n            "externalIpEgressBandwidthTier": "",\n            "totalEgressBandwidthTier": ""\n          },\n          "podCidrOverprovisionConfig": {},\n          "podIpv4CidrBlock": "",\n          "podRange": ""\n        },\n        "placementPolicy": {\n          "type": ""\n        },\n        "podIpv4CidrSize": 0,\n        "selfLink": "",\n        "status": "",\n        "statusMessage": "",\n        "updateInfo": {\n          "blueGreenInfo": {\n            "blueInstanceGroupUrls": [],\n            "bluePoolDeletionStartTime": "",\n            "greenInstanceGroupUrls": [],\n            "greenPoolVersion": "",\n            "phase": ""\n          }\n        },\n        "upgradeSettings": {},\n        "version": ""\n      }\n    ],\n    "notificationConfig": {\n      "pubsub": {\n        "enabled": false,\n        "filter": {\n          "eventType": []\n        },\n        "topic": ""\n      }\n    },\n    "podSecurityPolicyConfig": {\n      "enabled": false\n    },\n    "privateCluster": false,\n    "privateClusterConfig": {\n      "enablePrivateEndpoint": false,\n      "enablePrivateNodes": false,\n      "masterGlobalAccessConfig": {\n        "enabled": false\n      },\n      "masterIpv4CidrBlock": "",\n      "peeringName": "",\n      "privateEndpoint": "",\n      "privateEndpointSubnetwork": "",\n      "publicEndpoint": ""\n    },\n    "protectConfig": {\n      "workloadConfig": {\n        "auditMode": ""\n      },\n      "workloadVulnerabilityMode": ""\n    },\n    "releaseChannel": {\n      "channel": ""\n    },\n    "resourceLabels": {},\n    "resourceUsageExportConfig": {\n      "bigqueryDestination": {\n        "datasetId": ""\n      },\n      "consumptionMeteringConfig": {\n        "enabled": false\n      },\n      "enableNetworkEgressMetering": false\n    },\n    "selfLink": "",\n    "servicesIpv4Cidr": "",\n    "shieldedNodes": {\n      "enabled": false\n    },\n    "status": "",\n    "statusMessage": "",\n    "subnetwork": "",\n    "tpuConfig": {\n      "enabled": false,\n      "ipv4CidrBlock": "",\n      "useServiceNetworking": false\n    },\n    "tpuIpv4CidrBlock": "",\n    "verticalPodAutoscaling": {\n      "enabled": false\n    },\n    "workloadAltsConfig": {\n      "enableAlts": false\n    },\n    "workloadCertificates": {\n      "enableCertificates": false\n    },\n    "workloadIdentityConfig": {\n      "identityNamespace": "",\n      "identityProvider": "",\n      "workloadPool": ""\n    },\n    "zone": ""\n  },\n  "parent": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters',
  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({
  cluster: {
    addonsConfig: {
      cloudRunConfig: {disabled: false, loadBalancerType: ''},
      configConnectorConfig: {enabled: false},
      dnsCacheConfig: {enabled: false},
      gcePersistentDiskCsiDriverConfig: {enabled: false},
      gcpFilestoreCsiDriverConfig: {enabled: false},
      gkeBackupAgentConfig: {enabled: false},
      horizontalPodAutoscaling: {disabled: false},
      httpLoadBalancing: {disabled: false},
      istioConfig: {auth: '', disabled: false},
      kalmConfig: {enabled: false},
      kubernetesDashboard: {disabled: false},
      networkPolicyConfig: {disabled: false}
    },
    authenticatorGroupsConfig: {enabled: false, securityGroup: ''},
    autopilot: {enabled: false},
    autoscaling: {
      autoprovisioningLocations: [],
      autoprovisioningNodePoolDefaults: {
        bootDiskKmsKey: '',
        diskSizeGb: 0,
        diskType: '',
        imageType: '',
        management: {
          autoRepair: false,
          autoUpgrade: false,
          upgradeOptions: {autoUpgradeStartTime: '', description: ''}
        },
        minCpuPlatform: '',
        oauthScopes: [],
        serviceAccount: '',
        shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
        upgradeSettings: {
          blueGreenSettings: {
            nodePoolSoakDuration: '',
            standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
          },
          maxSurge: 0,
          maxUnavailable: 0,
          strategy: ''
        }
      },
      autoscalingProfile: '',
      enableNodeAutoprovisioning: false,
      resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
    },
    binaryAuthorization: {enabled: false, evaluationMode: ''},
    clusterIpv4Cidr: '',
    clusterTelemetry: {type: ''},
    conditions: [{canonicalCode: '', code: '', message: ''}],
    confidentialNodes: {enabled: false},
    costManagementConfig: {enabled: false},
    createTime: '',
    currentMasterVersion: '',
    currentNodeCount: 0,
    currentNodeVersion: '',
    databaseEncryption: {keyName: '', state: ''},
    defaultMaxPodsConstraint: {maxPodsPerNode: ''},
    description: '',
    enableKubernetesAlpha: false,
    enableTpu: false,
    endpoint: '',
    etag: '',
    expireTime: '',
    fleet: {membership: '', preRegistered: false, project: ''},
    id: '',
    identityServiceConfig: {enabled: false},
    initialClusterVersion: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    ipAllocationPolicy: {
      additionalPodRangesConfig: {podRangeNames: []},
      allowRouteOverlap: false,
      clusterIpv4Cidr: '',
      clusterIpv4CidrBlock: '',
      clusterSecondaryRangeName: '',
      createSubnetwork: false,
      ipv6AccessType: '',
      nodeIpv4Cidr: '',
      nodeIpv4CidrBlock: '',
      podCidrOverprovisionConfig: {disable: false},
      servicesIpv4Cidr: '',
      servicesIpv4CidrBlock: '',
      servicesIpv6CidrBlock: '',
      servicesSecondaryRangeName: '',
      stackType: '',
      subnetIpv6CidrBlock: '',
      subnetworkName: '',
      tpuIpv4CidrBlock: '',
      useIpAliases: false,
      useRoutes: false
    },
    labelFingerprint: '',
    legacyAbac: {enabled: false},
    location: '',
    locations: [],
    loggingConfig: {componentConfig: {enableComponents: []}},
    loggingService: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {duration: '', startTime: ''},
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
        }
      }
    },
    master: {},
    masterAuth: {
      clientCertificate: '',
      clientCertificateConfig: {issueClientCertificate: false},
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    masterAuthorizedNetworksConfig: {
      cidrBlocks: [{cidrBlock: '', displayName: ''}],
      enabled: false,
      gcpPublicCidrsAccessEnabled: false
    },
    masterIpv4CidrBlock: '',
    meshCertificates: {enableCertificates: false},
    monitoringConfig: {
      componentConfig: {enableComponents: []},
      managedPrometheusConfig: {enabled: false}
    },
    monitoringService: '',
    name: '',
    network: '',
    networkConfig: {
      datapathProvider: '',
      defaultSnatStatus: {disabled: false},
      dnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
      enableIntraNodeVisibility: false,
      enableL4ilbSubsetting: false,
      gatewayApiConfig: {channel: ''},
      network: '',
      privateIpv6GoogleAccess: '',
      serviceExternalIpsConfig: {enabled: false},
      subnetwork: ''
    },
    networkPolicy: {enabled: false, provider: ''},
    nodeConfig: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {threadsPerCore: ''},
      bootDiskKmsKey: '',
      confidentialNodes: {},
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {localSsdCount: 0},
      ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
      fastSocket: {enabled: false},
      gcfsConfig: {enabled: false},
      gvnic: {enabled: false},
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {cgroupMode: '', sysctls: {}},
      localNvmeSsdBlockConfig: {localSsdCount: 0},
      localSsdCount: 0,
      loggingConfig: {variantConfig: {variant: ''}},
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {consumeReservationType: '', key: '', values: []},
      resourceLabels: {},
      sandboxConfig: {sandboxType: '', type: ''},
      serviceAccount: '',
      shieldedInstanceConfig: {},
      spot: false,
      tags: [],
      taints: [{effect: '', key: '', value: ''}],
      windowsNodeConfig: {osVersion: ''},
      workloadMetadataConfig: {mode: '', nodeMetadata: ''}
    },
    nodeIpv4CidrSize: 0,
    nodePoolAutoConfig: {networkTags: {tags: []}},
    nodePoolDefaults: {nodeConfigDefaults: {gcfsConfig: {}, loggingConfig: {}}},
    nodePools: [
      {
        autoscaling: {
          autoprovisioned: false,
          enabled: false,
          locationPolicy: '',
          maxNodeCount: 0,
          minNodeCount: 0,
          totalMaxNodeCount: 0,
          totalMinNodeCount: 0
        },
        conditions: [{}],
        config: {},
        etag: '',
        initialNodeCount: 0,
        instanceGroupUrls: [],
        locations: [],
        management: {},
        maxPodsConstraint: {},
        name: '',
        networkConfig: {
          createPodRange: false,
          enablePrivateNodes: false,
          networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
          podCidrOverprovisionConfig: {},
          podIpv4CidrBlock: '',
          podRange: ''
        },
        placementPolicy: {type: ''},
        podIpv4CidrSize: 0,
        selfLink: '',
        status: '',
        statusMessage: '',
        updateInfo: {
          blueGreenInfo: {
            blueInstanceGroupUrls: [],
            bluePoolDeletionStartTime: '',
            greenInstanceGroupUrls: [],
            greenPoolVersion: '',
            phase: ''
          }
        },
        upgradeSettings: {},
        version: ''
      }
    ],
    notificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
    podSecurityPolicyConfig: {enabled: false},
    privateCluster: false,
    privateClusterConfig: {
      enablePrivateEndpoint: false,
      enablePrivateNodes: false,
      masterGlobalAccessConfig: {enabled: false},
      masterIpv4CidrBlock: '',
      peeringName: '',
      privateEndpoint: '',
      privateEndpointSubnetwork: '',
      publicEndpoint: ''
    },
    protectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
    releaseChannel: {channel: ''},
    resourceLabels: {},
    resourceUsageExportConfig: {
      bigqueryDestination: {datasetId: ''},
      consumptionMeteringConfig: {enabled: false},
      enableNetworkEgressMetering: false
    },
    selfLink: '',
    servicesIpv4Cidr: '',
    shieldedNodes: {enabled: false},
    status: '',
    statusMessage: '',
    subnetwork: '',
    tpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
    tpuIpv4CidrBlock: '',
    verticalPodAutoscaling: {enabled: false},
    workloadAltsConfig: {enableAlts: false},
    workloadCertificates: {enableCertificates: false},
    workloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
    zone: ''
  },
  parent: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters',
  headers: {'content-type': 'application/json'},
  body: {
    cluster: {
      addonsConfig: {
        cloudRunConfig: {disabled: false, loadBalancerType: ''},
        configConnectorConfig: {enabled: false},
        dnsCacheConfig: {enabled: false},
        gcePersistentDiskCsiDriverConfig: {enabled: false},
        gcpFilestoreCsiDriverConfig: {enabled: false},
        gkeBackupAgentConfig: {enabled: false},
        horizontalPodAutoscaling: {disabled: false},
        httpLoadBalancing: {disabled: false},
        istioConfig: {auth: '', disabled: false},
        kalmConfig: {enabled: false},
        kubernetesDashboard: {disabled: false},
        networkPolicyConfig: {disabled: false}
      },
      authenticatorGroupsConfig: {enabled: false, securityGroup: ''},
      autopilot: {enabled: false},
      autoscaling: {
        autoprovisioningLocations: [],
        autoprovisioningNodePoolDefaults: {
          bootDiskKmsKey: '',
          diskSizeGb: 0,
          diskType: '',
          imageType: '',
          management: {
            autoRepair: false,
            autoUpgrade: false,
            upgradeOptions: {autoUpgradeStartTime: '', description: ''}
          },
          minCpuPlatform: '',
          oauthScopes: [],
          serviceAccount: '',
          shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
          upgradeSettings: {
            blueGreenSettings: {
              nodePoolSoakDuration: '',
              standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
            },
            maxSurge: 0,
            maxUnavailable: 0,
            strategy: ''
          }
        },
        autoscalingProfile: '',
        enableNodeAutoprovisioning: false,
        resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
      },
      binaryAuthorization: {enabled: false, evaluationMode: ''},
      clusterIpv4Cidr: '',
      clusterTelemetry: {type: ''},
      conditions: [{canonicalCode: '', code: '', message: ''}],
      confidentialNodes: {enabled: false},
      costManagementConfig: {enabled: false},
      createTime: '',
      currentMasterVersion: '',
      currentNodeCount: 0,
      currentNodeVersion: '',
      databaseEncryption: {keyName: '', state: ''},
      defaultMaxPodsConstraint: {maxPodsPerNode: ''},
      description: '',
      enableKubernetesAlpha: false,
      enableTpu: false,
      endpoint: '',
      etag: '',
      expireTime: '',
      fleet: {membership: '', preRegistered: false, project: ''},
      id: '',
      identityServiceConfig: {enabled: false},
      initialClusterVersion: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      ipAllocationPolicy: {
        additionalPodRangesConfig: {podRangeNames: []},
        allowRouteOverlap: false,
        clusterIpv4Cidr: '',
        clusterIpv4CidrBlock: '',
        clusterSecondaryRangeName: '',
        createSubnetwork: false,
        ipv6AccessType: '',
        nodeIpv4Cidr: '',
        nodeIpv4CidrBlock: '',
        podCidrOverprovisionConfig: {disable: false},
        servicesIpv4Cidr: '',
        servicesIpv4CidrBlock: '',
        servicesIpv6CidrBlock: '',
        servicesSecondaryRangeName: '',
        stackType: '',
        subnetIpv6CidrBlock: '',
        subnetworkName: '',
        tpuIpv4CidrBlock: '',
        useIpAliases: false,
        useRoutes: false
      },
      labelFingerprint: '',
      legacyAbac: {enabled: false},
      location: '',
      locations: [],
      loggingConfig: {componentConfig: {enableComponents: []}},
      loggingService: '',
      maintenancePolicy: {
        resourceVersion: '',
        window: {
          dailyMaintenanceWindow: {duration: '', startTime: ''},
          maintenanceExclusions: {},
          recurringWindow: {
            recurrence: '',
            window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
          }
        }
      },
      master: {},
      masterAuth: {
        clientCertificate: '',
        clientCertificateConfig: {issueClientCertificate: false},
        clientKey: '',
        clusterCaCertificate: '',
        password: '',
        username: ''
      },
      masterAuthorizedNetworksConfig: {
        cidrBlocks: [{cidrBlock: '', displayName: ''}],
        enabled: false,
        gcpPublicCidrsAccessEnabled: false
      },
      masterIpv4CidrBlock: '',
      meshCertificates: {enableCertificates: false},
      monitoringConfig: {
        componentConfig: {enableComponents: []},
        managedPrometheusConfig: {enabled: false}
      },
      monitoringService: '',
      name: '',
      network: '',
      networkConfig: {
        datapathProvider: '',
        defaultSnatStatus: {disabled: false},
        dnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
        enableIntraNodeVisibility: false,
        enableL4ilbSubsetting: false,
        gatewayApiConfig: {channel: ''},
        network: '',
        privateIpv6GoogleAccess: '',
        serviceExternalIpsConfig: {enabled: false},
        subnetwork: ''
      },
      networkPolicy: {enabled: false, provider: ''},
      nodeConfig: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      nodeIpv4CidrSize: 0,
      nodePoolAutoConfig: {networkTags: {tags: []}},
      nodePoolDefaults: {nodeConfigDefaults: {gcfsConfig: {}, loggingConfig: {}}},
      nodePools: [
        {
          autoscaling: {
            autoprovisioned: false,
            enabled: false,
            locationPolicy: '',
            maxNodeCount: 0,
            minNodeCount: 0,
            totalMaxNodeCount: 0,
            totalMinNodeCount: 0
          },
          conditions: [{}],
          config: {},
          etag: '',
          initialNodeCount: 0,
          instanceGroupUrls: [],
          locations: [],
          management: {},
          maxPodsConstraint: {},
          name: '',
          networkConfig: {
            createPodRange: false,
            enablePrivateNodes: false,
            networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
            podCidrOverprovisionConfig: {},
            podIpv4CidrBlock: '',
            podRange: ''
          },
          placementPolicy: {type: ''},
          podIpv4CidrSize: 0,
          selfLink: '',
          status: '',
          statusMessage: '',
          updateInfo: {
            blueGreenInfo: {
              blueInstanceGroupUrls: [],
              bluePoolDeletionStartTime: '',
              greenInstanceGroupUrls: [],
              greenPoolVersion: '',
              phase: ''
            }
          },
          upgradeSettings: {},
          version: ''
        }
      ],
      notificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
      podSecurityPolicyConfig: {enabled: false},
      privateCluster: false,
      privateClusterConfig: {
        enablePrivateEndpoint: false,
        enablePrivateNodes: false,
        masterGlobalAccessConfig: {enabled: false},
        masterIpv4CidrBlock: '',
        peeringName: '',
        privateEndpoint: '',
        privateEndpointSubnetwork: '',
        publicEndpoint: ''
      },
      protectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
      releaseChannel: {channel: ''},
      resourceLabels: {},
      resourceUsageExportConfig: {
        bigqueryDestination: {datasetId: ''},
        consumptionMeteringConfig: {enabled: false},
        enableNetworkEgressMetering: false
      },
      selfLink: '',
      servicesIpv4Cidr: '',
      shieldedNodes: {enabled: false},
      status: '',
      statusMessage: '',
      subnetwork: '',
      tpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
      tpuIpv4CidrBlock: '',
      verticalPodAutoscaling: {enabled: false},
      workloadAltsConfig: {enableAlts: false},
      workloadCertificates: {enableCertificates: false},
      workloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
      zone: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  cluster: {
    addonsConfig: {
      cloudRunConfig: {
        disabled: false,
        loadBalancerType: ''
      },
      configConnectorConfig: {
        enabled: false
      },
      dnsCacheConfig: {
        enabled: false
      },
      gcePersistentDiskCsiDriverConfig: {
        enabled: false
      },
      gcpFilestoreCsiDriverConfig: {
        enabled: false
      },
      gkeBackupAgentConfig: {
        enabled: false
      },
      horizontalPodAutoscaling: {
        disabled: false
      },
      httpLoadBalancing: {
        disabled: false
      },
      istioConfig: {
        auth: '',
        disabled: false
      },
      kalmConfig: {
        enabled: false
      },
      kubernetesDashboard: {
        disabled: false
      },
      networkPolicyConfig: {
        disabled: false
      }
    },
    authenticatorGroupsConfig: {
      enabled: false,
      securityGroup: ''
    },
    autopilot: {
      enabled: false
    },
    autoscaling: {
      autoprovisioningLocations: [],
      autoprovisioningNodePoolDefaults: {
        bootDiskKmsKey: '',
        diskSizeGb: 0,
        diskType: '',
        imageType: '',
        management: {
          autoRepair: false,
          autoUpgrade: false,
          upgradeOptions: {
            autoUpgradeStartTime: '',
            description: ''
          }
        },
        minCpuPlatform: '',
        oauthScopes: [],
        serviceAccount: '',
        shieldedInstanceConfig: {
          enableIntegrityMonitoring: false,
          enableSecureBoot: false
        },
        upgradeSettings: {
          blueGreenSettings: {
            nodePoolSoakDuration: '',
            standardRolloutPolicy: {
              batchNodeCount: 0,
              batchPercentage: '',
              batchSoakDuration: ''
            }
          },
          maxSurge: 0,
          maxUnavailable: 0,
          strategy: ''
        }
      },
      autoscalingProfile: '',
      enableNodeAutoprovisioning: false,
      resourceLimits: [
        {
          maximum: '',
          minimum: '',
          resourceType: ''
        }
      ]
    },
    binaryAuthorization: {
      enabled: false,
      evaluationMode: ''
    },
    clusterIpv4Cidr: '',
    clusterTelemetry: {
      type: ''
    },
    conditions: [
      {
        canonicalCode: '',
        code: '',
        message: ''
      }
    ],
    confidentialNodes: {
      enabled: false
    },
    costManagementConfig: {
      enabled: false
    },
    createTime: '',
    currentMasterVersion: '',
    currentNodeCount: 0,
    currentNodeVersion: '',
    databaseEncryption: {
      keyName: '',
      state: ''
    },
    defaultMaxPodsConstraint: {
      maxPodsPerNode: ''
    },
    description: '',
    enableKubernetesAlpha: false,
    enableTpu: false,
    endpoint: '',
    etag: '',
    expireTime: '',
    fleet: {
      membership: '',
      preRegistered: false,
      project: ''
    },
    id: '',
    identityServiceConfig: {
      enabled: false
    },
    initialClusterVersion: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    ipAllocationPolicy: {
      additionalPodRangesConfig: {
        podRangeNames: []
      },
      allowRouteOverlap: false,
      clusterIpv4Cidr: '',
      clusterIpv4CidrBlock: '',
      clusterSecondaryRangeName: '',
      createSubnetwork: false,
      ipv6AccessType: '',
      nodeIpv4Cidr: '',
      nodeIpv4CidrBlock: '',
      podCidrOverprovisionConfig: {
        disable: false
      },
      servicesIpv4Cidr: '',
      servicesIpv4CidrBlock: '',
      servicesIpv6CidrBlock: '',
      servicesSecondaryRangeName: '',
      stackType: '',
      subnetIpv6CidrBlock: '',
      subnetworkName: '',
      tpuIpv4CidrBlock: '',
      useIpAliases: false,
      useRoutes: false
    },
    labelFingerprint: '',
    legacyAbac: {
      enabled: false
    },
    location: '',
    locations: [],
    loggingConfig: {
      componentConfig: {
        enableComponents: []
      }
    },
    loggingService: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {
          duration: '',
          startTime: ''
        },
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {
            endTime: '',
            maintenanceExclusionOptions: {
              scope: ''
            },
            startTime: ''
          }
        }
      }
    },
    master: {},
    masterAuth: {
      clientCertificate: '',
      clientCertificateConfig: {
        issueClientCertificate: false
      },
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    masterAuthorizedNetworksConfig: {
      cidrBlocks: [
        {
          cidrBlock: '',
          displayName: ''
        }
      ],
      enabled: false,
      gcpPublicCidrsAccessEnabled: false
    },
    masterIpv4CidrBlock: '',
    meshCertificates: {
      enableCertificates: false
    },
    monitoringConfig: {
      componentConfig: {
        enableComponents: []
      },
      managedPrometheusConfig: {
        enabled: false
      }
    },
    monitoringService: '',
    name: '',
    network: '',
    networkConfig: {
      datapathProvider: '',
      defaultSnatStatus: {
        disabled: false
      },
      dnsConfig: {
        clusterDns: '',
        clusterDnsDomain: '',
        clusterDnsScope: ''
      },
      enableIntraNodeVisibility: false,
      enableL4ilbSubsetting: false,
      gatewayApiConfig: {
        channel: ''
      },
      network: '',
      privateIpv6GoogleAccess: '',
      serviceExternalIpsConfig: {
        enabled: false
      },
      subnetwork: ''
    },
    networkPolicy: {
      enabled: false,
      provider: ''
    },
    nodeConfig: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {
            gpuSharingStrategy: '',
            maxSharedClientsPerGpu: ''
          },
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {
        threadsPerCore: ''
      },
      bootDiskKmsKey: '',
      confidentialNodes: {},
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {
        localSsdCount: 0
      },
      ephemeralStorageLocalSsdConfig: {
        localSsdCount: 0
      },
      fastSocket: {
        enabled: false
      },
      gcfsConfig: {
        enabled: false
      },
      gvnic: {
        enabled: false
      },
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {
        cgroupMode: '',
        sysctls: {}
      },
      localNvmeSsdBlockConfig: {
        localSsdCount: 0
      },
      localSsdCount: 0,
      loggingConfig: {
        variantConfig: {
          variant: ''
        }
      },
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {
        consumeReservationType: '',
        key: '',
        values: []
      },
      resourceLabels: {},
      sandboxConfig: {
        sandboxType: '',
        type: ''
      },
      serviceAccount: '',
      shieldedInstanceConfig: {},
      spot: false,
      tags: [],
      taints: [
        {
          effect: '',
          key: '',
          value: ''
        }
      ],
      windowsNodeConfig: {
        osVersion: ''
      },
      workloadMetadataConfig: {
        mode: '',
        nodeMetadata: ''
      }
    },
    nodeIpv4CidrSize: 0,
    nodePoolAutoConfig: {
      networkTags: {
        tags: []
      }
    },
    nodePoolDefaults: {
      nodeConfigDefaults: {
        gcfsConfig: {},
        loggingConfig: {}
      }
    },
    nodePools: [
      {
        autoscaling: {
          autoprovisioned: false,
          enabled: false,
          locationPolicy: '',
          maxNodeCount: 0,
          minNodeCount: 0,
          totalMaxNodeCount: 0,
          totalMinNodeCount: 0
        },
        conditions: [
          {}
        ],
        config: {},
        etag: '',
        initialNodeCount: 0,
        instanceGroupUrls: [],
        locations: [],
        management: {},
        maxPodsConstraint: {},
        name: '',
        networkConfig: {
          createPodRange: false,
          enablePrivateNodes: false,
          networkPerformanceConfig: {
            externalIpEgressBandwidthTier: '',
            totalEgressBandwidthTier: ''
          },
          podCidrOverprovisionConfig: {},
          podIpv4CidrBlock: '',
          podRange: ''
        },
        placementPolicy: {
          type: ''
        },
        podIpv4CidrSize: 0,
        selfLink: '',
        status: '',
        statusMessage: '',
        updateInfo: {
          blueGreenInfo: {
            blueInstanceGroupUrls: [],
            bluePoolDeletionStartTime: '',
            greenInstanceGroupUrls: [],
            greenPoolVersion: '',
            phase: ''
          }
        },
        upgradeSettings: {},
        version: ''
      }
    ],
    notificationConfig: {
      pubsub: {
        enabled: false,
        filter: {
          eventType: []
        },
        topic: ''
      }
    },
    podSecurityPolicyConfig: {
      enabled: false
    },
    privateCluster: false,
    privateClusterConfig: {
      enablePrivateEndpoint: false,
      enablePrivateNodes: false,
      masterGlobalAccessConfig: {
        enabled: false
      },
      masterIpv4CidrBlock: '',
      peeringName: '',
      privateEndpoint: '',
      privateEndpointSubnetwork: '',
      publicEndpoint: ''
    },
    protectConfig: {
      workloadConfig: {
        auditMode: ''
      },
      workloadVulnerabilityMode: ''
    },
    releaseChannel: {
      channel: ''
    },
    resourceLabels: {},
    resourceUsageExportConfig: {
      bigqueryDestination: {
        datasetId: ''
      },
      consumptionMeteringConfig: {
        enabled: false
      },
      enableNetworkEgressMetering: false
    },
    selfLink: '',
    servicesIpv4Cidr: '',
    shieldedNodes: {
      enabled: false
    },
    status: '',
    statusMessage: '',
    subnetwork: '',
    tpuConfig: {
      enabled: false,
      ipv4CidrBlock: '',
      useServiceNetworking: false
    },
    tpuIpv4CidrBlock: '',
    verticalPodAutoscaling: {
      enabled: false
    },
    workloadAltsConfig: {
      enableAlts: false
    },
    workloadCertificates: {
      enableCertificates: false
    },
    workloadIdentityConfig: {
      identityNamespace: '',
      identityProvider: '',
      workloadPool: ''
    },
    zone: ''
  },
  parent: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters',
  headers: {'content-type': 'application/json'},
  data: {
    cluster: {
      addonsConfig: {
        cloudRunConfig: {disabled: false, loadBalancerType: ''},
        configConnectorConfig: {enabled: false},
        dnsCacheConfig: {enabled: false},
        gcePersistentDiskCsiDriverConfig: {enabled: false},
        gcpFilestoreCsiDriverConfig: {enabled: false},
        gkeBackupAgentConfig: {enabled: false},
        horizontalPodAutoscaling: {disabled: false},
        httpLoadBalancing: {disabled: false},
        istioConfig: {auth: '', disabled: false},
        kalmConfig: {enabled: false},
        kubernetesDashboard: {disabled: false},
        networkPolicyConfig: {disabled: false}
      },
      authenticatorGroupsConfig: {enabled: false, securityGroup: ''},
      autopilot: {enabled: false},
      autoscaling: {
        autoprovisioningLocations: [],
        autoprovisioningNodePoolDefaults: {
          bootDiskKmsKey: '',
          diskSizeGb: 0,
          diskType: '',
          imageType: '',
          management: {
            autoRepair: false,
            autoUpgrade: false,
            upgradeOptions: {autoUpgradeStartTime: '', description: ''}
          },
          minCpuPlatform: '',
          oauthScopes: [],
          serviceAccount: '',
          shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
          upgradeSettings: {
            blueGreenSettings: {
              nodePoolSoakDuration: '',
              standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
            },
            maxSurge: 0,
            maxUnavailable: 0,
            strategy: ''
          }
        },
        autoscalingProfile: '',
        enableNodeAutoprovisioning: false,
        resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
      },
      binaryAuthorization: {enabled: false, evaluationMode: ''},
      clusterIpv4Cidr: '',
      clusterTelemetry: {type: ''},
      conditions: [{canonicalCode: '', code: '', message: ''}],
      confidentialNodes: {enabled: false},
      costManagementConfig: {enabled: false},
      createTime: '',
      currentMasterVersion: '',
      currentNodeCount: 0,
      currentNodeVersion: '',
      databaseEncryption: {keyName: '', state: ''},
      defaultMaxPodsConstraint: {maxPodsPerNode: ''},
      description: '',
      enableKubernetesAlpha: false,
      enableTpu: false,
      endpoint: '',
      etag: '',
      expireTime: '',
      fleet: {membership: '', preRegistered: false, project: ''},
      id: '',
      identityServiceConfig: {enabled: false},
      initialClusterVersion: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      ipAllocationPolicy: {
        additionalPodRangesConfig: {podRangeNames: []},
        allowRouteOverlap: false,
        clusterIpv4Cidr: '',
        clusterIpv4CidrBlock: '',
        clusterSecondaryRangeName: '',
        createSubnetwork: false,
        ipv6AccessType: '',
        nodeIpv4Cidr: '',
        nodeIpv4CidrBlock: '',
        podCidrOverprovisionConfig: {disable: false},
        servicesIpv4Cidr: '',
        servicesIpv4CidrBlock: '',
        servicesIpv6CidrBlock: '',
        servicesSecondaryRangeName: '',
        stackType: '',
        subnetIpv6CidrBlock: '',
        subnetworkName: '',
        tpuIpv4CidrBlock: '',
        useIpAliases: false,
        useRoutes: false
      },
      labelFingerprint: '',
      legacyAbac: {enabled: false},
      location: '',
      locations: [],
      loggingConfig: {componentConfig: {enableComponents: []}},
      loggingService: '',
      maintenancePolicy: {
        resourceVersion: '',
        window: {
          dailyMaintenanceWindow: {duration: '', startTime: ''},
          maintenanceExclusions: {},
          recurringWindow: {
            recurrence: '',
            window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
          }
        }
      },
      master: {},
      masterAuth: {
        clientCertificate: '',
        clientCertificateConfig: {issueClientCertificate: false},
        clientKey: '',
        clusterCaCertificate: '',
        password: '',
        username: ''
      },
      masterAuthorizedNetworksConfig: {
        cidrBlocks: [{cidrBlock: '', displayName: ''}],
        enabled: false,
        gcpPublicCidrsAccessEnabled: false
      },
      masterIpv4CidrBlock: '',
      meshCertificates: {enableCertificates: false},
      monitoringConfig: {
        componentConfig: {enableComponents: []},
        managedPrometheusConfig: {enabled: false}
      },
      monitoringService: '',
      name: '',
      network: '',
      networkConfig: {
        datapathProvider: '',
        defaultSnatStatus: {disabled: false},
        dnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
        enableIntraNodeVisibility: false,
        enableL4ilbSubsetting: false,
        gatewayApiConfig: {channel: ''},
        network: '',
        privateIpv6GoogleAccess: '',
        serviceExternalIpsConfig: {enabled: false},
        subnetwork: ''
      },
      networkPolicy: {enabled: false, provider: ''},
      nodeConfig: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      nodeIpv4CidrSize: 0,
      nodePoolAutoConfig: {networkTags: {tags: []}},
      nodePoolDefaults: {nodeConfigDefaults: {gcfsConfig: {}, loggingConfig: {}}},
      nodePools: [
        {
          autoscaling: {
            autoprovisioned: false,
            enabled: false,
            locationPolicy: '',
            maxNodeCount: 0,
            minNodeCount: 0,
            totalMaxNodeCount: 0,
            totalMinNodeCount: 0
          },
          conditions: [{}],
          config: {},
          etag: '',
          initialNodeCount: 0,
          instanceGroupUrls: [],
          locations: [],
          management: {},
          maxPodsConstraint: {},
          name: '',
          networkConfig: {
            createPodRange: false,
            enablePrivateNodes: false,
            networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
            podCidrOverprovisionConfig: {},
            podIpv4CidrBlock: '',
            podRange: ''
          },
          placementPolicy: {type: ''},
          podIpv4CidrSize: 0,
          selfLink: '',
          status: '',
          statusMessage: '',
          updateInfo: {
            blueGreenInfo: {
              blueInstanceGroupUrls: [],
              bluePoolDeletionStartTime: '',
              greenInstanceGroupUrls: [],
              greenPoolVersion: '',
              phase: ''
            }
          },
          upgradeSettings: {},
          version: ''
        }
      ],
      notificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
      podSecurityPolicyConfig: {enabled: false},
      privateCluster: false,
      privateClusterConfig: {
        enablePrivateEndpoint: false,
        enablePrivateNodes: false,
        masterGlobalAccessConfig: {enabled: false},
        masterIpv4CidrBlock: '',
        peeringName: '',
        privateEndpoint: '',
        privateEndpointSubnetwork: '',
        publicEndpoint: ''
      },
      protectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
      releaseChannel: {channel: ''},
      resourceLabels: {},
      resourceUsageExportConfig: {
        bigqueryDestination: {datasetId: ''},
        consumptionMeteringConfig: {enabled: false},
        enableNetworkEgressMetering: false
      },
      selfLink: '',
      servicesIpv4Cidr: '',
      shieldedNodes: {enabled: false},
      status: '',
      statusMessage: '',
      subnetwork: '',
      tpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
      tpuIpv4CidrBlock: '',
      verticalPodAutoscaling: {enabled: false},
      workloadAltsConfig: {enableAlts: false},
      workloadCertificates: {enableCertificates: false},
      workloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
      zone: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"cluster":{"addonsConfig":{"cloudRunConfig":{"disabled":false,"loadBalancerType":""},"configConnectorConfig":{"enabled":false},"dnsCacheConfig":{"enabled":false},"gcePersistentDiskCsiDriverConfig":{"enabled":false},"gcpFilestoreCsiDriverConfig":{"enabled":false},"gkeBackupAgentConfig":{"enabled":false},"horizontalPodAutoscaling":{"disabled":false},"httpLoadBalancing":{"disabled":false},"istioConfig":{"auth":"","disabled":false},"kalmConfig":{"enabled":false},"kubernetesDashboard":{"disabled":false},"networkPolicyConfig":{"disabled":false}},"authenticatorGroupsConfig":{"enabled":false,"securityGroup":""},"autopilot":{"enabled":false},"autoscaling":{"autoprovisioningLocations":[],"autoprovisioningNodePoolDefaults":{"bootDiskKmsKey":"","diskSizeGb":0,"diskType":"","imageType":"","management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"minCpuPlatform":"","oauthScopes":[],"serviceAccount":"","shieldedInstanceConfig":{"enableIntegrityMonitoring":false,"enableSecureBoot":false},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""}},"autoscalingProfile":"","enableNodeAutoprovisioning":false,"resourceLimits":[{"maximum":"","minimum":"","resourceType":""}]},"binaryAuthorization":{"enabled":false,"evaluationMode":""},"clusterIpv4Cidr":"","clusterTelemetry":{"type":""},"conditions":[{"canonicalCode":"","code":"","message":""}],"confidentialNodes":{"enabled":false},"costManagementConfig":{"enabled":false},"createTime":"","currentMasterVersion":"","currentNodeCount":0,"currentNodeVersion":"","databaseEncryption":{"keyName":"","state":""},"defaultMaxPodsConstraint":{"maxPodsPerNode":""},"description":"","enableKubernetesAlpha":false,"enableTpu":false,"endpoint":"","etag":"","expireTime":"","fleet":{"membership":"","preRegistered":false,"project":""},"id":"","identityServiceConfig":{"enabled":false},"initialClusterVersion":"","initialNodeCount":0,"instanceGroupUrls":[],"ipAllocationPolicy":{"additionalPodRangesConfig":{"podRangeNames":[]},"allowRouteOverlap":false,"clusterIpv4Cidr":"","clusterIpv4CidrBlock":"","clusterSecondaryRangeName":"","createSubnetwork":false,"ipv6AccessType":"","nodeIpv4Cidr":"","nodeIpv4CidrBlock":"","podCidrOverprovisionConfig":{"disable":false},"servicesIpv4Cidr":"","servicesIpv4CidrBlock":"","servicesIpv6CidrBlock":"","servicesSecondaryRangeName":"","stackType":"","subnetIpv6CidrBlock":"","subnetworkName":"","tpuIpv4CidrBlock":"","useIpAliases":false,"useRoutes":false},"labelFingerprint":"","legacyAbac":{"enabled":false},"location":"","locations":[],"loggingConfig":{"componentConfig":{"enableComponents":[]}},"loggingService":"","maintenancePolicy":{"resourceVersion":"","window":{"dailyMaintenanceWindow":{"duration":"","startTime":""},"maintenanceExclusions":{},"recurringWindow":{"recurrence":"","window":{"endTime":"","maintenanceExclusionOptions":{"scope":""},"startTime":""}}}},"master":{},"masterAuth":{"clientCertificate":"","clientCertificateConfig":{"issueClientCertificate":false},"clientKey":"","clusterCaCertificate":"","password":"","username":""},"masterAuthorizedNetworksConfig":{"cidrBlocks":[{"cidrBlock":"","displayName":""}],"enabled":false,"gcpPublicCidrsAccessEnabled":false},"masterIpv4CidrBlock":"","meshCertificates":{"enableCertificates":false},"monitoringConfig":{"componentConfig":{"enableComponents":[]},"managedPrometheusConfig":{"enabled":false}},"monitoringService":"","name":"","network":"","networkConfig":{"datapathProvider":"","defaultSnatStatus":{"disabled":false},"dnsConfig":{"clusterDns":"","clusterDnsDomain":"","clusterDnsScope":""},"enableIntraNodeVisibility":false,"enableL4ilbSubsetting":false,"gatewayApiConfig":{"channel":""},"network":"","privateIpv6GoogleAccess":"","serviceExternalIpsConfig":{"enabled":false},"subnetwork":""},"networkPolicy":{"enabled":false,"provider":""},"nodeConfig":{"accelerators":[{"acceleratorCount":"","acceleratorType":"","gpuPartitionSize":"","gpuSharingConfig":{"gpuSharingStrategy":"","maxSharedClientsPerGpu":""},"maxTimeSharedClientsPerGpu":""}],"advancedMachineFeatures":{"threadsPerCore":""},"bootDiskKmsKey":"","confidentialNodes":{},"diskSizeGb":0,"diskType":"","ephemeralStorageConfig":{"localSsdCount":0},"ephemeralStorageLocalSsdConfig":{"localSsdCount":0},"fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"localNvmeSsdBlockConfig":{"localSsdCount":0},"localSsdCount":0,"loggingConfig":{"variantConfig":{"variant":""}},"machineType":"","metadata":{},"minCpuPlatform":"","nodeGroup":"","oauthScopes":[],"preemptible":false,"reservationAffinity":{"consumeReservationType":"","key":"","values":[]},"resourceLabels":{},"sandboxConfig":{"sandboxType":"","type":""},"serviceAccount":"","shieldedInstanceConfig":{},"spot":false,"tags":[],"taints":[{"effect":"","key":"","value":""}],"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""}},"nodeIpv4CidrSize":0,"nodePoolAutoConfig":{"networkTags":{"tags":[]}},"nodePoolDefaults":{"nodeConfigDefaults":{"gcfsConfig":{},"loggingConfig":{}}},"nodePools":[{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"conditions":[{}],"config":{},"etag":"","initialNodeCount":0,"instanceGroupUrls":[],"locations":[],"management":{},"maxPodsConstraint":{},"name":"","networkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{},"podIpv4CidrBlock":"","podRange":""},"placementPolicy":{"type":""},"podIpv4CidrSize":0,"selfLink":"","status":"","statusMessage":"","updateInfo":{"blueGreenInfo":{"blueInstanceGroupUrls":[],"bluePoolDeletionStartTime":"","greenInstanceGroupUrls":[],"greenPoolVersion":"","phase":""}},"upgradeSettings":{},"version":""}],"notificationConfig":{"pubsub":{"enabled":false,"filter":{"eventType":[]},"topic":""}},"podSecurityPolicyConfig":{"enabled":false},"privateCluster":false,"privateClusterConfig":{"enablePrivateEndpoint":false,"enablePrivateNodes":false,"masterGlobalAccessConfig":{"enabled":false},"masterIpv4CidrBlock":"","peeringName":"","privateEndpoint":"","privateEndpointSubnetwork":"","publicEndpoint":""},"protectConfig":{"workloadConfig":{"auditMode":""},"workloadVulnerabilityMode":""},"releaseChannel":{"channel":""},"resourceLabels":{},"resourceUsageExportConfig":{"bigqueryDestination":{"datasetId":""},"consumptionMeteringConfig":{"enabled":false},"enableNetworkEgressMetering":false},"selfLink":"","servicesIpv4Cidr":"","shieldedNodes":{"enabled":false},"status":"","statusMessage":"","subnetwork":"","tpuConfig":{"enabled":false,"ipv4CidrBlock":"","useServiceNetworking":false},"tpuIpv4CidrBlock":"","verticalPodAutoscaling":{"enabled":false},"workloadAltsConfig":{"enableAlts":false},"workloadCertificates":{"enableCertificates":false},"workloadIdentityConfig":{"identityNamespace":"","identityProvider":"","workloadPool":""},"zone":""},"parent":"","projectId":"","zone":""}'
};

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 = @{ @"cluster": @{ @"addonsConfig": @{ @"cloudRunConfig": @{ @"disabled": @NO, @"loadBalancerType": @"" }, @"configConnectorConfig": @{ @"enabled": @NO }, @"dnsCacheConfig": @{ @"enabled": @NO }, @"gcePersistentDiskCsiDriverConfig": @{ @"enabled": @NO }, @"gcpFilestoreCsiDriverConfig": @{ @"enabled": @NO }, @"gkeBackupAgentConfig": @{ @"enabled": @NO }, @"horizontalPodAutoscaling": @{ @"disabled": @NO }, @"httpLoadBalancing": @{ @"disabled": @NO }, @"istioConfig": @{ @"auth": @"", @"disabled": @NO }, @"kalmConfig": @{ @"enabled": @NO }, @"kubernetesDashboard": @{ @"disabled": @NO }, @"networkPolicyConfig": @{ @"disabled": @NO } }, @"authenticatorGroupsConfig": @{ @"enabled": @NO, @"securityGroup": @"" }, @"autopilot": @{ @"enabled": @NO }, @"autoscaling": @{ @"autoprovisioningLocations": @[  ], @"autoprovisioningNodePoolDefaults": @{ @"bootDiskKmsKey": @"", @"diskSizeGb": @0, @"diskType": @"", @"imageType": @"", @"management": @{ @"autoRepair": @NO, @"autoUpgrade": @NO, @"upgradeOptions": @{ @"autoUpgradeStartTime": @"", @"description": @"" } }, @"minCpuPlatform": @"", @"oauthScopes": @[  ], @"serviceAccount": @"", @"shieldedInstanceConfig": @{ @"enableIntegrityMonitoring": @NO, @"enableSecureBoot": @NO }, @"upgradeSettings": @{ @"blueGreenSettings": @{ @"nodePoolSoakDuration": @"", @"standardRolloutPolicy": @{ @"batchNodeCount": @0, @"batchPercentage": @"", @"batchSoakDuration": @"" } }, @"maxSurge": @0, @"maxUnavailable": @0, @"strategy": @"" } }, @"autoscalingProfile": @"", @"enableNodeAutoprovisioning": @NO, @"resourceLimits": @[ @{ @"maximum": @"", @"minimum": @"", @"resourceType": @"" } ] }, @"binaryAuthorization": @{ @"enabled": @NO, @"evaluationMode": @"" }, @"clusterIpv4Cidr": @"", @"clusterTelemetry": @{ @"type": @"" }, @"conditions": @[ @{ @"canonicalCode": @"", @"code": @"", @"message": @"" } ], @"confidentialNodes": @{ @"enabled": @NO }, @"costManagementConfig": @{ @"enabled": @NO }, @"createTime": @"", @"currentMasterVersion": @"", @"currentNodeCount": @0, @"currentNodeVersion": @"", @"databaseEncryption": @{ @"keyName": @"", @"state": @"" }, @"defaultMaxPodsConstraint": @{ @"maxPodsPerNode": @"" }, @"description": @"", @"enableKubernetesAlpha": @NO, @"enableTpu": @NO, @"endpoint": @"", @"etag": @"", @"expireTime": @"", @"fleet": @{ @"membership": @"", @"preRegistered": @NO, @"project": @"" }, @"id": @"", @"identityServiceConfig": @{ @"enabled": @NO }, @"initialClusterVersion": @"", @"initialNodeCount": @0, @"instanceGroupUrls": @[  ], @"ipAllocationPolicy": @{ @"additionalPodRangesConfig": @{ @"podRangeNames": @[  ] }, @"allowRouteOverlap": @NO, @"clusterIpv4Cidr": @"", @"clusterIpv4CidrBlock": @"", @"clusterSecondaryRangeName": @"", @"createSubnetwork": @NO, @"ipv6AccessType": @"", @"nodeIpv4Cidr": @"", @"nodeIpv4CidrBlock": @"", @"podCidrOverprovisionConfig": @{ @"disable": @NO }, @"servicesIpv4Cidr": @"", @"servicesIpv4CidrBlock": @"", @"servicesIpv6CidrBlock": @"", @"servicesSecondaryRangeName": @"", @"stackType": @"", @"subnetIpv6CidrBlock": @"", @"subnetworkName": @"", @"tpuIpv4CidrBlock": @"", @"useIpAliases": @NO, @"useRoutes": @NO }, @"labelFingerprint": @"", @"legacyAbac": @{ @"enabled": @NO }, @"location": @"", @"locations": @[  ], @"loggingConfig": @{ @"componentConfig": @{ @"enableComponents": @[  ] } }, @"loggingService": @"", @"maintenancePolicy": @{ @"resourceVersion": @"", @"window": @{ @"dailyMaintenanceWindow": @{ @"duration": @"", @"startTime": @"" }, @"maintenanceExclusions": @{  }, @"recurringWindow": @{ @"recurrence": @"", @"window": @{ @"endTime": @"", @"maintenanceExclusionOptions": @{ @"scope": @"" }, @"startTime": @"" } } } }, @"master": @{  }, @"masterAuth": @{ @"clientCertificate": @"", @"clientCertificateConfig": @{ @"issueClientCertificate": @NO }, @"clientKey": @"", @"clusterCaCertificate": @"", @"password": @"", @"username": @"" }, @"masterAuthorizedNetworksConfig": @{ @"cidrBlocks": @[ @{ @"cidrBlock": @"", @"displayName": @"" } ], @"enabled": @NO, @"gcpPublicCidrsAccessEnabled": @NO }, @"masterIpv4CidrBlock": @"", @"meshCertificates": @{ @"enableCertificates": @NO }, @"monitoringConfig": @{ @"componentConfig": @{ @"enableComponents": @[  ] }, @"managedPrometheusConfig": @{ @"enabled": @NO } }, @"monitoringService": @"", @"name": @"", @"network": @"", @"networkConfig": @{ @"datapathProvider": @"", @"defaultSnatStatus": @{ @"disabled": @NO }, @"dnsConfig": @{ @"clusterDns": @"", @"clusterDnsDomain": @"", @"clusterDnsScope": @"" }, @"enableIntraNodeVisibility": @NO, @"enableL4ilbSubsetting": @NO, @"gatewayApiConfig": @{ @"channel": @"" }, @"network": @"", @"privateIpv6GoogleAccess": @"", @"serviceExternalIpsConfig": @{ @"enabled": @NO }, @"subnetwork": @"" }, @"networkPolicy": @{ @"enabled": @NO, @"provider": @"" }, @"nodeConfig": @{ @"accelerators": @[ @{ @"acceleratorCount": @"", @"acceleratorType": @"", @"gpuPartitionSize": @"", @"gpuSharingConfig": @{ @"gpuSharingStrategy": @"", @"maxSharedClientsPerGpu": @"" }, @"maxTimeSharedClientsPerGpu": @"" } ], @"advancedMachineFeatures": @{ @"threadsPerCore": @"" }, @"bootDiskKmsKey": @"", @"confidentialNodes": @{  }, @"diskSizeGb": @0, @"diskType": @"", @"ephemeralStorageConfig": @{ @"localSsdCount": @0 }, @"ephemeralStorageLocalSsdConfig": @{ @"localSsdCount": @0 }, @"fastSocket": @{ @"enabled": @NO }, @"gcfsConfig": @{ @"enabled": @NO }, @"gvnic": @{ @"enabled": @NO }, @"imageType": @"", @"kubeletConfig": @{ @"cpuCfsQuota": @NO, @"cpuCfsQuotaPeriod": @"", @"cpuManagerPolicy": @"", @"podPidsLimit": @"" }, @"labels": @{  }, @"linuxNodeConfig": @{ @"cgroupMode": @"", @"sysctls": @{  } }, @"localNvmeSsdBlockConfig": @{ @"localSsdCount": @0 }, @"localSsdCount": @0, @"loggingConfig": @{ @"variantConfig": @{ @"variant": @"" } }, @"machineType": @"", @"metadata": @{  }, @"minCpuPlatform": @"", @"nodeGroup": @"", @"oauthScopes": @[  ], @"preemptible": @NO, @"reservationAffinity": @{ @"consumeReservationType": @"", @"key": @"", @"values": @[  ] }, @"resourceLabels": @{  }, @"sandboxConfig": @{ @"sandboxType": @"", @"type": @"" }, @"serviceAccount": @"", @"shieldedInstanceConfig": @{  }, @"spot": @NO, @"tags": @[  ], @"taints": @[ @{ @"effect": @"", @"key": @"", @"value": @"" } ], @"windowsNodeConfig": @{ @"osVersion": @"" }, @"workloadMetadataConfig": @{ @"mode": @"", @"nodeMetadata": @"" } }, @"nodeIpv4CidrSize": @0, @"nodePoolAutoConfig": @{ @"networkTags": @{ @"tags": @[  ] } }, @"nodePoolDefaults": @{ @"nodeConfigDefaults": @{ @"gcfsConfig": @{  }, @"loggingConfig": @{  } } }, @"nodePools": @[ @{ @"autoscaling": @{ @"autoprovisioned": @NO, @"enabled": @NO, @"locationPolicy": @"", @"maxNodeCount": @0, @"minNodeCount": @0, @"totalMaxNodeCount": @0, @"totalMinNodeCount": @0 }, @"conditions": @[ @{  } ], @"config": @{  }, @"etag": @"", @"initialNodeCount": @0, @"instanceGroupUrls": @[  ], @"locations": @[  ], @"management": @{  }, @"maxPodsConstraint": @{  }, @"name": @"", @"networkConfig": @{ @"createPodRange": @NO, @"enablePrivateNodes": @NO, @"networkPerformanceConfig": @{ @"externalIpEgressBandwidthTier": @"", @"totalEgressBandwidthTier": @"" }, @"podCidrOverprovisionConfig": @{  }, @"podIpv4CidrBlock": @"", @"podRange": @"" }, @"placementPolicy": @{ @"type": @"" }, @"podIpv4CidrSize": @0, @"selfLink": @"", @"status": @"", @"statusMessage": @"", @"updateInfo": @{ @"blueGreenInfo": @{ @"blueInstanceGroupUrls": @[  ], @"bluePoolDeletionStartTime": @"", @"greenInstanceGroupUrls": @[  ], @"greenPoolVersion": @"", @"phase": @"" } }, @"upgradeSettings": @{  }, @"version": @"" } ], @"notificationConfig": @{ @"pubsub": @{ @"enabled": @NO, @"filter": @{ @"eventType": @[  ] }, @"topic": @"" } }, @"podSecurityPolicyConfig": @{ @"enabled": @NO }, @"privateCluster": @NO, @"privateClusterConfig": @{ @"enablePrivateEndpoint": @NO, @"enablePrivateNodes": @NO, @"masterGlobalAccessConfig": @{ @"enabled": @NO }, @"masterIpv4CidrBlock": @"", @"peeringName": @"", @"privateEndpoint": @"", @"privateEndpointSubnetwork": @"", @"publicEndpoint": @"" }, @"protectConfig": @{ @"workloadConfig": @{ @"auditMode": @"" }, @"workloadVulnerabilityMode": @"" }, @"releaseChannel": @{ @"channel": @"" }, @"resourceLabels": @{  }, @"resourceUsageExportConfig": @{ @"bigqueryDestination": @{ @"datasetId": @"" }, @"consumptionMeteringConfig": @{ @"enabled": @NO }, @"enableNetworkEgressMetering": @NO }, @"selfLink": @"", @"servicesIpv4Cidr": @"", @"shieldedNodes": @{ @"enabled": @NO }, @"status": @"", @"statusMessage": @"", @"subnetwork": @"", @"tpuConfig": @{ @"enabled": @NO, @"ipv4CidrBlock": @"", @"useServiceNetworking": @NO }, @"tpuIpv4CidrBlock": @"", @"verticalPodAutoscaling": @{ @"enabled": @NO }, @"workloadAltsConfig": @{ @"enableAlts": @NO }, @"workloadCertificates": @{ @"enableCertificates": @NO }, @"workloadIdentityConfig": @{ @"identityNamespace": @"", @"identityProvider": @"", @"workloadPool": @"" }, @"zone": @"" },
                              @"parent": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters",
  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([
    'cluster' => [
        'addonsConfig' => [
                'cloudRunConfig' => [
                                'disabled' => null,
                                'loadBalancerType' => ''
                ],
                'configConnectorConfig' => [
                                'enabled' => null
                ],
                'dnsCacheConfig' => [
                                'enabled' => null
                ],
                'gcePersistentDiskCsiDriverConfig' => [
                                'enabled' => null
                ],
                'gcpFilestoreCsiDriverConfig' => [
                                'enabled' => null
                ],
                'gkeBackupAgentConfig' => [
                                'enabled' => null
                ],
                'horizontalPodAutoscaling' => [
                                'disabled' => null
                ],
                'httpLoadBalancing' => [
                                'disabled' => null
                ],
                'istioConfig' => [
                                'auth' => '',
                                'disabled' => null
                ],
                'kalmConfig' => [
                                'enabled' => null
                ],
                'kubernetesDashboard' => [
                                'disabled' => null
                ],
                'networkPolicyConfig' => [
                                'disabled' => null
                ]
        ],
        'authenticatorGroupsConfig' => [
                'enabled' => null,
                'securityGroup' => ''
        ],
        'autopilot' => [
                'enabled' => null
        ],
        'autoscaling' => [
                'autoprovisioningLocations' => [
                                
                ],
                'autoprovisioningNodePoolDefaults' => [
                                'bootDiskKmsKey' => '',
                                'diskSizeGb' => 0,
                                'diskType' => '',
                                'imageType' => '',
                                'management' => [
                                                                'autoRepair' => null,
                                                                'autoUpgrade' => null,
                                                                'upgradeOptions' => [
                                                                                                                                'autoUpgradeStartTime' => '',
                                                                                                                                'description' => ''
                                                                ]
                                ],
                                'minCpuPlatform' => '',
                                'oauthScopes' => [
                                                                
                                ],
                                'serviceAccount' => '',
                                'shieldedInstanceConfig' => [
                                                                'enableIntegrityMonitoring' => null,
                                                                'enableSecureBoot' => null
                                ],
                                'upgradeSettings' => [
                                                                'blueGreenSettings' => [
                                                                                                                                'nodePoolSoakDuration' => '',
                                                                                                                                'standardRolloutPolicy' => [
                                                                                                                                                                                                                                                                'batchNodeCount' => 0,
                                                                                                                                                                                                                                                                'batchPercentage' => '',
                                                                                                                                                                                                                                                                'batchSoakDuration' => ''
                                                                                                                                ]
                                                                ],
                                                                'maxSurge' => 0,
                                                                'maxUnavailable' => 0,
                                                                'strategy' => ''
                                ]
                ],
                'autoscalingProfile' => '',
                'enableNodeAutoprovisioning' => null,
                'resourceLimits' => [
                                [
                                                                'maximum' => '',
                                                                'minimum' => '',
                                                                'resourceType' => ''
                                ]
                ]
        ],
        'binaryAuthorization' => [
                'enabled' => null,
                'evaluationMode' => ''
        ],
        'clusterIpv4Cidr' => '',
        'clusterTelemetry' => [
                'type' => ''
        ],
        'conditions' => [
                [
                                'canonicalCode' => '',
                                'code' => '',
                                'message' => ''
                ]
        ],
        'confidentialNodes' => [
                'enabled' => null
        ],
        'costManagementConfig' => [
                'enabled' => null
        ],
        'createTime' => '',
        'currentMasterVersion' => '',
        'currentNodeCount' => 0,
        'currentNodeVersion' => '',
        'databaseEncryption' => [
                'keyName' => '',
                'state' => ''
        ],
        'defaultMaxPodsConstraint' => [
                'maxPodsPerNode' => ''
        ],
        'description' => '',
        'enableKubernetesAlpha' => null,
        'enableTpu' => null,
        'endpoint' => '',
        'etag' => '',
        'expireTime' => '',
        'fleet' => [
                'membership' => '',
                'preRegistered' => null,
                'project' => ''
        ],
        'id' => '',
        'identityServiceConfig' => [
                'enabled' => null
        ],
        'initialClusterVersion' => '',
        'initialNodeCount' => 0,
        'instanceGroupUrls' => [
                
        ],
        'ipAllocationPolicy' => [
                'additionalPodRangesConfig' => [
                                'podRangeNames' => [
                                                                
                                ]
                ],
                'allowRouteOverlap' => null,
                'clusterIpv4Cidr' => '',
                'clusterIpv4CidrBlock' => '',
                'clusterSecondaryRangeName' => '',
                'createSubnetwork' => null,
                'ipv6AccessType' => '',
                'nodeIpv4Cidr' => '',
                'nodeIpv4CidrBlock' => '',
                'podCidrOverprovisionConfig' => [
                                'disable' => null
                ],
                'servicesIpv4Cidr' => '',
                'servicesIpv4CidrBlock' => '',
                'servicesIpv6CidrBlock' => '',
                'servicesSecondaryRangeName' => '',
                'stackType' => '',
                'subnetIpv6CidrBlock' => '',
                'subnetworkName' => '',
                'tpuIpv4CidrBlock' => '',
                'useIpAliases' => null,
                'useRoutes' => null
        ],
        'labelFingerprint' => '',
        'legacyAbac' => [
                'enabled' => null
        ],
        'location' => '',
        'locations' => [
                
        ],
        'loggingConfig' => [
                'componentConfig' => [
                                'enableComponents' => [
                                                                
                                ]
                ]
        ],
        'loggingService' => '',
        'maintenancePolicy' => [
                'resourceVersion' => '',
                'window' => [
                                'dailyMaintenanceWindow' => [
                                                                'duration' => '',
                                                                'startTime' => ''
                                ],
                                'maintenanceExclusions' => [
                                                                
                                ],
                                'recurringWindow' => [
                                                                'recurrence' => '',
                                                                'window' => [
                                                                                                                                'endTime' => '',
                                                                                                                                'maintenanceExclusionOptions' => [
                                                                                                                                                                                                                                                                'scope' => ''
                                                                                                                                ],
                                                                                                                                'startTime' => ''
                                                                ]
                                ]
                ]
        ],
        'master' => [
                
        ],
        'masterAuth' => [
                'clientCertificate' => '',
                'clientCertificateConfig' => [
                                'issueClientCertificate' => null
                ],
                'clientKey' => '',
                'clusterCaCertificate' => '',
                'password' => '',
                'username' => ''
        ],
        'masterAuthorizedNetworksConfig' => [
                'cidrBlocks' => [
                                [
                                                                'cidrBlock' => '',
                                                                'displayName' => ''
                                ]
                ],
                'enabled' => null,
                'gcpPublicCidrsAccessEnabled' => null
        ],
        'masterIpv4CidrBlock' => '',
        'meshCertificates' => [
                'enableCertificates' => null
        ],
        'monitoringConfig' => [
                'componentConfig' => [
                                'enableComponents' => [
                                                                
                                ]
                ],
                'managedPrometheusConfig' => [
                                'enabled' => null
                ]
        ],
        'monitoringService' => '',
        'name' => '',
        'network' => '',
        'networkConfig' => [
                'datapathProvider' => '',
                'defaultSnatStatus' => [
                                'disabled' => null
                ],
                'dnsConfig' => [
                                'clusterDns' => '',
                                'clusterDnsDomain' => '',
                                'clusterDnsScope' => ''
                ],
                'enableIntraNodeVisibility' => null,
                'enableL4ilbSubsetting' => null,
                'gatewayApiConfig' => [
                                'channel' => ''
                ],
                'network' => '',
                'privateIpv6GoogleAccess' => '',
                'serviceExternalIpsConfig' => [
                                'enabled' => null
                ],
                'subnetwork' => ''
        ],
        'networkPolicy' => [
                'enabled' => null,
                'provider' => ''
        ],
        'nodeConfig' => [
                'accelerators' => [
                                [
                                                                'acceleratorCount' => '',
                                                                'acceleratorType' => '',
                                                                'gpuPartitionSize' => '',
                                                                'gpuSharingConfig' => [
                                                                                                                                'gpuSharingStrategy' => '',
                                                                                                                                'maxSharedClientsPerGpu' => ''
                                                                ],
                                                                'maxTimeSharedClientsPerGpu' => ''
                                ]
                ],
                'advancedMachineFeatures' => [
                                'threadsPerCore' => ''
                ],
                'bootDiskKmsKey' => '',
                'confidentialNodes' => [
                                
                ],
                'diskSizeGb' => 0,
                'diskType' => '',
                'ephemeralStorageConfig' => [
                                'localSsdCount' => 0
                ],
                'ephemeralStorageLocalSsdConfig' => [
                                'localSsdCount' => 0
                ],
                'fastSocket' => [
                                'enabled' => null
                ],
                'gcfsConfig' => [
                                'enabled' => null
                ],
                'gvnic' => [
                                'enabled' => null
                ],
                'imageType' => '',
                'kubeletConfig' => [
                                'cpuCfsQuota' => null,
                                'cpuCfsQuotaPeriod' => '',
                                'cpuManagerPolicy' => '',
                                'podPidsLimit' => ''
                ],
                'labels' => [
                                
                ],
                'linuxNodeConfig' => [
                                'cgroupMode' => '',
                                'sysctls' => [
                                                                
                                ]
                ],
                'localNvmeSsdBlockConfig' => [
                                'localSsdCount' => 0
                ],
                'localSsdCount' => 0,
                'loggingConfig' => [
                                'variantConfig' => [
                                                                'variant' => ''
                                ]
                ],
                'machineType' => '',
                'metadata' => [
                                
                ],
                'minCpuPlatform' => '',
                'nodeGroup' => '',
                'oauthScopes' => [
                                
                ],
                'preemptible' => null,
                'reservationAffinity' => [
                                'consumeReservationType' => '',
                                'key' => '',
                                'values' => [
                                                                
                                ]
                ],
                'resourceLabels' => [
                                
                ],
                'sandboxConfig' => [
                                'sandboxType' => '',
                                'type' => ''
                ],
                'serviceAccount' => '',
                'shieldedInstanceConfig' => [
                                
                ],
                'spot' => null,
                'tags' => [
                                
                ],
                'taints' => [
                                [
                                                                'effect' => '',
                                                                'key' => '',
                                                                'value' => ''
                                ]
                ],
                'windowsNodeConfig' => [
                                'osVersion' => ''
                ],
                'workloadMetadataConfig' => [
                                'mode' => '',
                                'nodeMetadata' => ''
                ]
        ],
        'nodeIpv4CidrSize' => 0,
        'nodePoolAutoConfig' => [
                'networkTags' => [
                                'tags' => [
                                                                
                                ]
                ]
        ],
        'nodePoolDefaults' => [
                'nodeConfigDefaults' => [
                                'gcfsConfig' => [
                                                                
                                ],
                                'loggingConfig' => [
                                                                
                                ]
                ]
        ],
        'nodePools' => [
                [
                                'autoscaling' => [
                                                                'autoprovisioned' => null,
                                                                'enabled' => null,
                                                                'locationPolicy' => '',
                                                                'maxNodeCount' => 0,
                                                                'minNodeCount' => 0,
                                                                'totalMaxNodeCount' => 0,
                                                                'totalMinNodeCount' => 0
                                ],
                                'conditions' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'config' => [
                                                                
                                ],
                                'etag' => '',
                                'initialNodeCount' => 0,
                                'instanceGroupUrls' => [
                                                                
                                ],
                                'locations' => [
                                                                
                                ],
                                'management' => [
                                                                
                                ],
                                'maxPodsConstraint' => [
                                                                
                                ],
                                'name' => '',
                                'networkConfig' => [
                                                                'createPodRange' => null,
                                                                'enablePrivateNodes' => null,
                                                                'networkPerformanceConfig' => [
                                                                                                                                'externalIpEgressBandwidthTier' => '',
                                                                                                                                'totalEgressBandwidthTier' => ''
                                                                ],
                                                                'podCidrOverprovisionConfig' => [
                                                                                                                                
                                                                ],
                                                                'podIpv4CidrBlock' => '',
                                                                'podRange' => ''
                                ],
                                'placementPolicy' => [
                                                                'type' => ''
                                ],
                                'podIpv4CidrSize' => 0,
                                'selfLink' => '',
                                'status' => '',
                                'statusMessage' => '',
                                'updateInfo' => [
                                                                'blueGreenInfo' => [
                                                                                                                                'blueInstanceGroupUrls' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'bluePoolDeletionStartTime' => '',
                                                                                                                                'greenInstanceGroupUrls' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'greenPoolVersion' => '',
                                                                                                                                'phase' => ''
                                                                ]
                                ],
                                'upgradeSettings' => [
                                                                
                                ],
                                'version' => ''
                ]
        ],
        'notificationConfig' => [
                'pubsub' => [
                                'enabled' => null,
                                'filter' => [
                                                                'eventType' => [
                                                                                                                                
                                                                ]
                                ],
                                'topic' => ''
                ]
        ],
        'podSecurityPolicyConfig' => [
                'enabled' => null
        ],
        'privateCluster' => null,
        'privateClusterConfig' => [
                'enablePrivateEndpoint' => null,
                'enablePrivateNodes' => null,
                'masterGlobalAccessConfig' => [
                                'enabled' => null
                ],
                'masterIpv4CidrBlock' => '',
                'peeringName' => '',
                'privateEndpoint' => '',
                'privateEndpointSubnetwork' => '',
                'publicEndpoint' => ''
        ],
        'protectConfig' => [
                'workloadConfig' => [
                                'auditMode' => ''
                ],
                'workloadVulnerabilityMode' => ''
        ],
        'releaseChannel' => [
                'channel' => ''
        ],
        'resourceLabels' => [
                
        ],
        'resourceUsageExportConfig' => [
                'bigqueryDestination' => [
                                'datasetId' => ''
                ],
                'consumptionMeteringConfig' => [
                                'enabled' => null
                ],
                'enableNetworkEgressMetering' => null
        ],
        'selfLink' => '',
        'servicesIpv4Cidr' => '',
        'shieldedNodes' => [
                'enabled' => null
        ],
        'status' => '',
        'statusMessage' => '',
        'subnetwork' => '',
        'tpuConfig' => [
                'enabled' => null,
                'ipv4CidrBlock' => '',
                'useServiceNetworking' => null
        ],
        'tpuIpv4CidrBlock' => '',
        'verticalPodAutoscaling' => [
                'enabled' => null
        ],
        'workloadAltsConfig' => [
                'enableAlts' => null
        ],
        'workloadCertificates' => [
                'enableCertificates' => null
        ],
        'workloadIdentityConfig' => [
                'identityNamespace' => '',
                'identityProvider' => '',
                'workloadPool' => ''
        ],
        'zone' => ''
    ],
    'parent' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters', [
  'body' => '{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'cluster' => [
    'addonsConfig' => [
        'cloudRunConfig' => [
                'disabled' => null,
                'loadBalancerType' => ''
        ],
        'configConnectorConfig' => [
                'enabled' => null
        ],
        'dnsCacheConfig' => [
                'enabled' => null
        ],
        'gcePersistentDiskCsiDriverConfig' => [
                'enabled' => null
        ],
        'gcpFilestoreCsiDriverConfig' => [
                'enabled' => null
        ],
        'gkeBackupAgentConfig' => [
                'enabled' => null
        ],
        'horizontalPodAutoscaling' => [
                'disabled' => null
        ],
        'httpLoadBalancing' => [
                'disabled' => null
        ],
        'istioConfig' => [
                'auth' => '',
                'disabled' => null
        ],
        'kalmConfig' => [
                'enabled' => null
        ],
        'kubernetesDashboard' => [
                'disabled' => null
        ],
        'networkPolicyConfig' => [
                'disabled' => null
        ]
    ],
    'authenticatorGroupsConfig' => [
        'enabled' => null,
        'securityGroup' => ''
    ],
    'autopilot' => [
        'enabled' => null
    ],
    'autoscaling' => [
        'autoprovisioningLocations' => [
                
        ],
        'autoprovisioningNodePoolDefaults' => [
                'bootDiskKmsKey' => '',
                'diskSizeGb' => 0,
                'diskType' => '',
                'imageType' => '',
                'management' => [
                                'autoRepair' => null,
                                'autoUpgrade' => null,
                                'upgradeOptions' => [
                                                                'autoUpgradeStartTime' => '',
                                                                'description' => ''
                                ]
                ],
                'minCpuPlatform' => '',
                'oauthScopes' => [
                                
                ],
                'serviceAccount' => '',
                'shieldedInstanceConfig' => [
                                'enableIntegrityMonitoring' => null,
                                'enableSecureBoot' => null
                ],
                'upgradeSettings' => [
                                'blueGreenSettings' => [
                                                                'nodePoolSoakDuration' => '',
                                                                'standardRolloutPolicy' => [
                                                                                                                                'batchNodeCount' => 0,
                                                                                                                                'batchPercentage' => '',
                                                                                                                                'batchSoakDuration' => ''
                                                                ]
                                ],
                                'maxSurge' => 0,
                                'maxUnavailable' => 0,
                                'strategy' => ''
                ]
        ],
        'autoscalingProfile' => '',
        'enableNodeAutoprovisioning' => null,
        'resourceLimits' => [
                [
                                'maximum' => '',
                                'minimum' => '',
                                'resourceType' => ''
                ]
        ]
    ],
    'binaryAuthorization' => [
        'enabled' => null,
        'evaluationMode' => ''
    ],
    'clusterIpv4Cidr' => '',
    'clusterTelemetry' => [
        'type' => ''
    ],
    'conditions' => [
        [
                'canonicalCode' => '',
                'code' => '',
                'message' => ''
        ]
    ],
    'confidentialNodes' => [
        'enabled' => null
    ],
    'costManagementConfig' => [
        'enabled' => null
    ],
    'createTime' => '',
    'currentMasterVersion' => '',
    'currentNodeCount' => 0,
    'currentNodeVersion' => '',
    'databaseEncryption' => [
        'keyName' => '',
        'state' => ''
    ],
    'defaultMaxPodsConstraint' => [
        'maxPodsPerNode' => ''
    ],
    'description' => '',
    'enableKubernetesAlpha' => null,
    'enableTpu' => null,
    'endpoint' => '',
    'etag' => '',
    'expireTime' => '',
    'fleet' => [
        'membership' => '',
        'preRegistered' => null,
        'project' => ''
    ],
    'id' => '',
    'identityServiceConfig' => [
        'enabled' => null
    ],
    'initialClusterVersion' => '',
    'initialNodeCount' => 0,
    'instanceGroupUrls' => [
        
    ],
    'ipAllocationPolicy' => [
        'additionalPodRangesConfig' => [
                'podRangeNames' => [
                                
                ]
        ],
        'allowRouteOverlap' => null,
        'clusterIpv4Cidr' => '',
        'clusterIpv4CidrBlock' => '',
        'clusterSecondaryRangeName' => '',
        'createSubnetwork' => null,
        'ipv6AccessType' => '',
        'nodeIpv4Cidr' => '',
        'nodeIpv4CidrBlock' => '',
        'podCidrOverprovisionConfig' => [
                'disable' => null
        ],
        'servicesIpv4Cidr' => '',
        'servicesIpv4CidrBlock' => '',
        'servicesIpv6CidrBlock' => '',
        'servicesSecondaryRangeName' => '',
        'stackType' => '',
        'subnetIpv6CidrBlock' => '',
        'subnetworkName' => '',
        'tpuIpv4CidrBlock' => '',
        'useIpAliases' => null,
        'useRoutes' => null
    ],
    'labelFingerprint' => '',
    'legacyAbac' => [
        'enabled' => null
    ],
    'location' => '',
    'locations' => [
        
    ],
    'loggingConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ]
    ],
    'loggingService' => '',
    'maintenancePolicy' => [
        'resourceVersion' => '',
        'window' => [
                'dailyMaintenanceWindow' => [
                                'duration' => '',
                                'startTime' => ''
                ],
                'maintenanceExclusions' => [
                                
                ],
                'recurringWindow' => [
                                'recurrence' => '',
                                'window' => [
                                                                'endTime' => '',
                                                                'maintenanceExclusionOptions' => [
                                                                                                                                'scope' => ''
                                                                ],
                                                                'startTime' => ''
                                ]
                ]
        ]
    ],
    'master' => [
        
    ],
    'masterAuth' => [
        'clientCertificate' => '',
        'clientCertificateConfig' => [
                'issueClientCertificate' => null
        ],
        'clientKey' => '',
        'clusterCaCertificate' => '',
        'password' => '',
        'username' => ''
    ],
    'masterAuthorizedNetworksConfig' => [
        'cidrBlocks' => [
                [
                                'cidrBlock' => '',
                                'displayName' => ''
                ]
        ],
        'enabled' => null,
        'gcpPublicCidrsAccessEnabled' => null
    ],
    'masterIpv4CidrBlock' => '',
    'meshCertificates' => [
        'enableCertificates' => null
    ],
    'monitoringConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ],
        'managedPrometheusConfig' => [
                'enabled' => null
        ]
    ],
    'monitoringService' => '',
    'name' => '',
    'network' => '',
    'networkConfig' => [
        'datapathProvider' => '',
        'defaultSnatStatus' => [
                'disabled' => null
        ],
        'dnsConfig' => [
                'clusterDns' => '',
                'clusterDnsDomain' => '',
                'clusterDnsScope' => ''
        ],
        'enableIntraNodeVisibility' => null,
        'enableL4ilbSubsetting' => null,
        'gatewayApiConfig' => [
                'channel' => ''
        ],
        'network' => '',
        'privateIpv6GoogleAccess' => '',
        'serviceExternalIpsConfig' => [
                'enabled' => null
        ],
        'subnetwork' => ''
    ],
    'networkPolicy' => [
        'enabled' => null,
        'provider' => ''
    ],
    'nodeConfig' => [
        'accelerators' => [
                [
                                'acceleratorCount' => '',
                                'acceleratorType' => '',
                                'gpuPartitionSize' => '',
                                'gpuSharingConfig' => [
                                                                'gpuSharingStrategy' => '',
                                                                'maxSharedClientsPerGpu' => ''
                                ],
                                'maxTimeSharedClientsPerGpu' => ''
                ]
        ],
        'advancedMachineFeatures' => [
                'threadsPerCore' => ''
        ],
        'bootDiskKmsKey' => '',
        'confidentialNodes' => [
                
        ],
        'diskSizeGb' => 0,
        'diskType' => '',
        'ephemeralStorageConfig' => [
                'localSsdCount' => 0
        ],
        'ephemeralStorageLocalSsdConfig' => [
                'localSsdCount' => 0
        ],
        'fastSocket' => [
                'enabled' => null
        ],
        'gcfsConfig' => [
                'enabled' => null
        ],
        'gvnic' => [
                'enabled' => null
        ],
        'imageType' => '',
        'kubeletConfig' => [
                'cpuCfsQuota' => null,
                'cpuCfsQuotaPeriod' => '',
                'cpuManagerPolicy' => '',
                'podPidsLimit' => ''
        ],
        'labels' => [
                
        ],
        'linuxNodeConfig' => [
                'cgroupMode' => '',
                'sysctls' => [
                                
                ]
        ],
        'localNvmeSsdBlockConfig' => [
                'localSsdCount' => 0
        ],
        'localSsdCount' => 0,
        'loggingConfig' => [
                'variantConfig' => [
                                'variant' => ''
                ]
        ],
        'machineType' => '',
        'metadata' => [
                
        ],
        'minCpuPlatform' => '',
        'nodeGroup' => '',
        'oauthScopes' => [
                
        ],
        'preemptible' => null,
        'reservationAffinity' => [
                'consumeReservationType' => '',
                'key' => '',
                'values' => [
                                
                ]
        ],
        'resourceLabels' => [
                
        ],
        'sandboxConfig' => [
                'sandboxType' => '',
                'type' => ''
        ],
        'serviceAccount' => '',
        'shieldedInstanceConfig' => [
                
        ],
        'spot' => null,
        'tags' => [
                
        ],
        'taints' => [
                [
                                'effect' => '',
                                'key' => '',
                                'value' => ''
                ]
        ],
        'windowsNodeConfig' => [
                'osVersion' => ''
        ],
        'workloadMetadataConfig' => [
                'mode' => '',
                'nodeMetadata' => ''
        ]
    ],
    'nodeIpv4CidrSize' => 0,
    'nodePoolAutoConfig' => [
        'networkTags' => [
                'tags' => [
                                
                ]
        ]
    ],
    'nodePoolDefaults' => [
        'nodeConfigDefaults' => [
                'gcfsConfig' => [
                                
                ],
                'loggingConfig' => [
                                
                ]
        ]
    ],
    'nodePools' => [
        [
                'autoscaling' => [
                                'autoprovisioned' => null,
                                'enabled' => null,
                                'locationPolicy' => '',
                                'maxNodeCount' => 0,
                                'minNodeCount' => 0,
                                'totalMaxNodeCount' => 0,
                                'totalMinNodeCount' => 0
                ],
                'conditions' => [
                                [
                                                                
                                ]
                ],
                'config' => [
                                
                ],
                'etag' => '',
                'initialNodeCount' => 0,
                'instanceGroupUrls' => [
                                
                ],
                'locations' => [
                                
                ],
                'management' => [
                                
                ],
                'maxPodsConstraint' => [
                                
                ],
                'name' => '',
                'networkConfig' => [
                                'createPodRange' => null,
                                'enablePrivateNodes' => null,
                                'networkPerformanceConfig' => [
                                                                'externalIpEgressBandwidthTier' => '',
                                                                'totalEgressBandwidthTier' => ''
                                ],
                                'podCidrOverprovisionConfig' => [
                                                                
                                ],
                                'podIpv4CidrBlock' => '',
                                'podRange' => ''
                ],
                'placementPolicy' => [
                                'type' => ''
                ],
                'podIpv4CidrSize' => 0,
                'selfLink' => '',
                'status' => '',
                'statusMessage' => '',
                'updateInfo' => [
                                'blueGreenInfo' => [
                                                                'blueInstanceGroupUrls' => [
                                                                                                                                
                                                                ],
                                                                'bluePoolDeletionStartTime' => '',
                                                                'greenInstanceGroupUrls' => [
                                                                                                                                
                                                                ],
                                                                'greenPoolVersion' => '',
                                                                'phase' => ''
                                ]
                ],
                'upgradeSettings' => [
                                
                ],
                'version' => ''
        ]
    ],
    'notificationConfig' => [
        'pubsub' => [
                'enabled' => null,
                'filter' => [
                                'eventType' => [
                                                                
                                ]
                ],
                'topic' => ''
        ]
    ],
    'podSecurityPolicyConfig' => [
        'enabled' => null
    ],
    'privateCluster' => null,
    'privateClusterConfig' => [
        'enablePrivateEndpoint' => null,
        'enablePrivateNodes' => null,
        'masterGlobalAccessConfig' => [
                'enabled' => null
        ],
        'masterIpv4CidrBlock' => '',
        'peeringName' => '',
        'privateEndpoint' => '',
        'privateEndpointSubnetwork' => '',
        'publicEndpoint' => ''
    ],
    'protectConfig' => [
        'workloadConfig' => [
                'auditMode' => ''
        ],
        'workloadVulnerabilityMode' => ''
    ],
    'releaseChannel' => [
        'channel' => ''
    ],
    'resourceLabels' => [
        
    ],
    'resourceUsageExportConfig' => [
        'bigqueryDestination' => [
                'datasetId' => ''
        ],
        'consumptionMeteringConfig' => [
                'enabled' => null
        ],
        'enableNetworkEgressMetering' => null
    ],
    'selfLink' => '',
    'servicesIpv4Cidr' => '',
    'shieldedNodes' => [
        'enabled' => null
    ],
    'status' => '',
    'statusMessage' => '',
    'subnetwork' => '',
    'tpuConfig' => [
        'enabled' => null,
        'ipv4CidrBlock' => '',
        'useServiceNetworking' => null
    ],
    'tpuIpv4CidrBlock' => '',
    'verticalPodAutoscaling' => [
        'enabled' => null
    ],
    'workloadAltsConfig' => [
        'enableAlts' => null
    ],
    'workloadCertificates' => [
        'enableCertificates' => null
    ],
    'workloadIdentityConfig' => [
        'identityNamespace' => '',
        'identityProvider' => '',
        'workloadPool' => ''
    ],
    'zone' => ''
  ],
  'parent' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'cluster' => [
    'addonsConfig' => [
        'cloudRunConfig' => [
                'disabled' => null,
                'loadBalancerType' => ''
        ],
        'configConnectorConfig' => [
                'enabled' => null
        ],
        'dnsCacheConfig' => [
                'enabled' => null
        ],
        'gcePersistentDiskCsiDriverConfig' => [
                'enabled' => null
        ],
        'gcpFilestoreCsiDriverConfig' => [
                'enabled' => null
        ],
        'gkeBackupAgentConfig' => [
                'enabled' => null
        ],
        'horizontalPodAutoscaling' => [
                'disabled' => null
        ],
        'httpLoadBalancing' => [
                'disabled' => null
        ],
        'istioConfig' => [
                'auth' => '',
                'disabled' => null
        ],
        'kalmConfig' => [
                'enabled' => null
        ],
        'kubernetesDashboard' => [
                'disabled' => null
        ],
        'networkPolicyConfig' => [
                'disabled' => null
        ]
    ],
    'authenticatorGroupsConfig' => [
        'enabled' => null,
        'securityGroup' => ''
    ],
    'autopilot' => [
        'enabled' => null
    ],
    'autoscaling' => [
        'autoprovisioningLocations' => [
                
        ],
        'autoprovisioningNodePoolDefaults' => [
                'bootDiskKmsKey' => '',
                'diskSizeGb' => 0,
                'diskType' => '',
                'imageType' => '',
                'management' => [
                                'autoRepair' => null,
                                'autoUpgrade' => null,
                                'upgradeOptions' => [
                                                                'autoUpgradeStartTime' => '',
                                                                'description' => ''
                                ]
                ],
                'minCpuPlatform' => '',
                'oauthScopes' => [
                                
                ],
                'serviceAccount' => '',
                'shieldedInstanceConfig' => [
                                'enableIntegrityMonitoring' => null,
                                'enableSecureBoot' => null
                ],
                'upgradeSettings' => [
                                'blueGreenSettings' => [
                                                                'nodePoolSoakDuration' => '',
                                                                'standardRolloutPolicy' => [
                                                                                                                                'batchNodeCount' => 0,
                                                                                                                                'batchPercentage' => '',
                                                                                                                                'batchSoakDuration' => ''
                                                                ]
                                ],
                                'maxSurge' => 0,
                                'maxUnavailable' => 0,
                                'strategy' => ''
                ]
        ],
        'autoscalingProfile' => '',
        'enableNodeAutoprovisioning' => null,
        'resourceLimits' => [
                [
                                'maximum' => '',
                                'minimum' => '',
                                'resourceType' => ''
                ]
        ]
    ],
    'binaryAuthorization' => [
        'enabled' => null,
        'evaluationMode' => ''
    ],
    'clusterIpv4Cidr' => '',
    'clusterTelemetry' => [
        'type' => ''
    ],
    'conditions' => [
        [
                'canonicalCode' => '',
                'code' => '',
                'message' => ''
        ]
    ],
    'confidentialNodes' => [
        'enabled' => null
    ],
    'costManagementConfig' => [
        'enabled' => null
    ],
    'createTime' => '',
    'currentMasterVersion' => '',
    'currentNodeCount' => 0,
    'currentNodeVersion' => '',
    'databaseEncryption' => [
        'keyName' => '',
        'state' => ''
    ],
    'defaultMaxPodsConstraint' => [
        'maxPodsPerNode' => ''
    ],
    'description' => '',
    'enableKubernetesAlpha' => null,
    'enableTpu' => null,
    'endpoint' => '',
    'etag' => '',
    'expireTime' => '',
    'fleet' => [
        'membership' => '',
        'preRegistered' => null,
        'project' => ''
    ],
    'id' => '',
    'identityServiceConfig' => [
        'enabled' => null
    ],
    'initialClusterVersion' => '',
    'initialNodeCount' => 0,
    'instanceGroupUrls' => [
        
    ],
    'ipAllocationPolicy' => [
        'additionalPodRangesConfig' => [
                'podRangeNames' => [
                                
                ]
        ],
        'allowRouteOverlap' => null,
        'clusterIpv4Cidr' => '',
        'clusterIpv4CidrBlock' => '',
        'clusterSecondaryRangeName' => '',
        'createSubnetwork' => null,
        'ipv6AccessType' => '',
        'nodeIpv4Cidr' => '',
        'nodeIpv4CidrBlock' => '',
        'podCidrOverprovisionConfig' => [
                'disable' => null
        ],
        'servicesIpv4Cidr' => '',
        'servicesIpv4CidrBlock' => '',
        'servicesIpv6CidrBlock' => '',
        'servicesSecondaryRangeName' => '',
        'stackType' => '',
        'subnetIpv6CidrBlock' => '',
        'subnetworkName' => '',
        'tpuIpv4CidrBlock' => '',
        'useIpAliases' => null,
        'useRoutes' => null
    ],
    'labelFingerprint' => '',
    'legacyAbac' => [
        'enabled' => null
    ],
    'location' => '',
    'locations' => [
        
    ],
    'loggingConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ]
    ],
    'loggingService' => '',
    'maintenancePolicy' => [
        'resourceVersion' => '',
        'window' => [
                'dailyMaintenanceWindow' => [
                                'duration' => '',
                                'startTime' => ''
                ],
                'maintenanceExclusions' => [
                                
                ],
                'recurringWindow' => [
                                'recurrence' => '',
                                'window' => [
                                                                'endTime' => '',
                                                                'maintenanceExclusionOptions' => [
                                                                                                                                'scope' => ''
                                                                ],
                                                                'startTime' => ''
                                ]
                ]
        ]
    ],
    'master' => [
        
    ],
    'masterAuth' => [
        'clientCertificate' => '',
        'clientCertificateConfig' => [
                'issueClientCertificate' => null
        ],
        'clientKey' => '',
        'clusterCaCertificate' => '',
        'password' => '',
        'username' => ''
    ],
    'masterAuthorizedNetworksConfig' => [
        'cidrBlocks' => [
                [
                                'cidrBlock' => '',
                                'displayName' => ''
                ]
        ],
        'enabled' => null,
        'gcpPublicCidrsAccessEnabled' => null
    ],
    'masterIpv4CidrBlock' => '',
    'meshCertificates' => [
        'enableCertificates' => null
    ],
    'monitoringConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ],
        'managedPrometheusConfig' => [
                'enabled' => null
        ]
    ],
    'monitoringService' => '',
    'name' => '',
    'network' => '',
    'networkConfig' => [
        'datapathProvider' => '',
        'defaultSnatStatus' => [
                'disabled' => null
        ],
        'dnsConfig' => [
                'clusterDns' => '',
                'clusterDnsDomain' => '',
                'clusterDnsScope' => ''
        ],
        'enableIntraNodeVisibility' => null,
        'enableL4ilbSubsetting' => null,
        'gatewayApiConfig' => [
                'channel' => ''
        ],
        'network' => '',
        'privateIpv6GoogleAccess' => '',
        'serviceExternalIpsConfig' => [
                'enabled' => null
        ],
        'subnetwork' => ''
    ],
    'networkPolicy' => [
        'enabled' => null,
        'provider' => ''
    ],
    'nodeConfig' => [
        'accelerators' => [
                [
                                'acceleratorCount' => '',
                                'acceleratorType' => '',
                                'gpuPartitionSize' => '',
                                'gpuSharingConfig' => [
                                                                'gpuSharingStrategy' => '',
                                                                'maxSharedClientsPerGpu' => ''
                                ],
                                'maxTimeSharedClientsPerGpu' => ''
                ]
        ],
        'advancedMachineFeatures' => [
                'threadsPerCore' => ''
        ],
        'bootDiskKmsKey' => '',
        'confidentialNodes' => [
                
        ],
        'diskSizeGb' => 0,
        'diskType' => '',
        'ephemeralStorageConfig' => [
                'localSsdCount' => 0
        ],
        'ephemeralStorageLocalSsdConfig' => [
                'localSsdCount' => 0
        ],
        'fastSocket' => [
                'enabled' => null
        ],
        'gcfsConfig' => [
                'enabled' => null
        ],
        'gvnic' => [
                'enabled' => null
        ],
        'imageType' => '',
        'kubeletConfig' => [
                'cpuCfsQuota' => null,
                'cpuCfsQuotaPeriod' => '',
                'cpuManagerPolicy' => '',
                'podPidsLimit' => ''
        ],
        'labels' => [
                
        ],
        'linuxNodeConfig' => [
                'cgroupMode' => '',
                'sysctls' => [
                                
                ]
        ],
        'localNvmeSsdBlockConfig' => [
                'localSsdCount' => 0
        ],
        'localSsdCount' => 0,
        'loggingConfig' => [
                'variantConfig' => [
                                'variant' => ''
                ]
        ],
        'machineType' => '',
        'metadata' => [
                
        ],
        'minCpuPlatform' => '',
        'nodeGroup' => '',
        'oauthScopes' => [
                
        ],
        'preemptible' => null,
        'reservationAffinity' => [
                'consumeReservationType' => '',
                'key' => '',
                'values' => [
                                
                ]
        ],
        'resourceLabels' => [
                
        ],
        'sandboxConfig' => [
                'sandboxType' => '',
                'type' => ''
        ],
        'serviceAccount' => '',
        'shieldedInstanceConfig' => [
                
        ],
        'spot' => null,
        'tags' => [
                
        ],
        'taints' => [
                [
                                'effect' => '',
                                'key' => '',
                                'value' => ''
                ]
        ],
        'windowsNodeConfig' => [
                'osVersion' => ''
        ],
        'workloadMetadataConfig' => [
                'mode' => '',
                'nodeMetadata' => ''
        ]
    ],
    'nodeIpv4CidrSize' => 0,
    'nodePoolAutoConfig' => [
        'networkTags' => [
                'tags' => [
                                
                ]
        ]
    ],
    'nodePoolDefaults' => [
        'nodeConfigDefaults' => [
                'gcfsConfig' => [
                                
                ],
                'loggingConfig' => [
                                
                ]
        ]
    ],
    'nodePools' => [
        [
                'autoscaling' => [
                                'autoprovisioned' => null,
                                'enabled' => null,
                                'locationPolicy' => '',
                                'maxNodeCount' => 0,
                                'minNodeCount' => 0,
                                'totalMaxNodeCount' => 0,
                                'totalMinNodeCount' => 0
                ],
                'conditions' => [
                                [
                                                                
                                ]
                ],
                'config' => [
                                
                ],
                'etag' => '',
                'initialNodeCount' => 0,
                'instanceGroupUrls' => [
                                
                ],
                'locations' => [
                                
                ],
                'management' => [
                                
                ],
                'maxPodsConstraint' => [
                                
                ],
                'name' => '',
                'networkConfig' => [
                                'createPodRange' => null,
                                'enablePrivateNodes' => null,
                                'networkPerformanceConfig' => [
                                                                'externalIpEgressBandwidthTier' => '',
                                                                'totalEgressBandwidthTier' => ''
                                ],
                                'podCidrOverprovisionConfig' => [
                                                                
                                ],
                                'podIpv4CidrBlock' => '',
                                'podRange' => ''
                ],
                'placementPolicy' => [
                                'type' => ''
                ],
                'podIpv4CidrSize' => 0,
                'selfLink' => '',
                'status' => '',
                'statusMessage' => '',
                'updateInfo' => [
                                'blueGreenInfo' => [
                                                                'blueInstanceGroupUrls' => [
                                                                                                                                
                                                                ],
                                                                'bluePoolDeletionStartTime' => '',
                                                                'greenInstanceGroupUrls' => [
                                                                                                                                
                                                                ],
                                                                'greenPoolVersion' => '',
                                                                'phase' => ''
                                ]
                ],
                'upgradeSettings' => [
                                
                ],
                'version' => ''
        ]
    ],
    'notificationConfig' => [
        'pubsub' => [
                'enabled' => null,
                'filter' => [
                                'eventType' => [
                                                                
                                ]
                ],
                'topic' => ''
        ]
    ],
    'podSecurityPolicyConfig' => [
        'enabled' => null
    ],
    'privateCluster' => null,
    'privateClusterConfig' => [
        'enablePrivateEndpoint' => null,
        'enablePrivateNodes' => null,
        'masterGlobalAccessConfig' => [
                'enabled' => null
        ],
        'masterIpv4CidrBlock' => '',
        'peeringName' => '',
        'privateEndpoint' => '',
        'privateEndpointSubnetwork' => '',
        'publicEndpoint' => ''
    ],
    'protectConfig' => [
        'workloadConfig' => [
                'auditMode' => ''
        ],
        'workloadVulnerabilityMode' => ''
    ],
    'releaseChannel' => [
        'channel' => ''
    ],
    'resourceLabels' => [
        
    ],
    'resourceUsageExportConfig' => [
        'bigqueryDestination' => [
                'datasetId' => ''
        ],
        'consumptionMeteringConfig' => [
                'enabled' => null
        ],
        'enableNetworkEgressMetering' => null
    ],
    'selfLink' => '',
    'servicesIpv4Cidr' => '',
    'shieldedNodes' => [
        'enabled' => null
    ],
    'status' => '',
    'statusMessage' => '',
    'subnetwork' => '',
    'tpuConfig' => [
        'enabled' => null,
        'ipv4CidrBlock' => '',
        'useServiceNetworking' => null
    ],
    'tpuIpv4CidrBlock' => '',
    'verticalPodAutoscaling' => [
        'enabled' => null
    ],
    'workloadAltsConfig' => [
        'enableAlts' => null
    ],
    'workloadCertificates' => [
        'enableCertificates' => null
    ],
    'workloadIdentityConfig' => [
        'identityNamespace' => '',
        'identityProvider' => '',
        'workloadPool' => ''
    ],
    'zone' => ''
  ],
  'parent' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters"

payload = {
    "cluster": {
        "addonsConfig": {
            "cloudRunConfig": {
                "disabled": False,
                "loadBalancerType": ""
            },
            "configConnectorConfig": { "enabled": False },
            "dnsCacheConfig": { "enabled": False },
            "gcePersistentDiskCsiDriverConfig": { "enabled": False },
            "gcpFilestoreCsiDriverConfig": { "enabled": False },
            "gkeBackupAgentConfig": { "enabled": False },
            "horizontalPodAutoscaling": { "disabled": False },
            "httpLoadBalancing": { "disabled": False },
            "istioConfig": {
                "auth": "",
                "disabled": False
            },
            "kalmConfig": { "enabled": False },
            "kubernetesDashboard": { "disabled": False },
            "networkPolicyConfig": { "disabled": False }
        },
        "authenticatorGroupsConfig": {
            "enabled": False,
            "securityGroup": ""
        },
        "autopilot": { "enabled": False },
        "autoscaling": {
            "autoprovisioningLocations": [],
            "autoprovisioningNodePoolDefaults": {
                "bootDiskKmsKey": "",
                "diskSizeGb": 0,
                "diskType": "",
                "imageType": "",
                "management": {
                    "autoRepair": False,
                    "autoUpgrade": False,
                    "upgradeOptions": {
                        "autoUpgradeStartTime": "",
                        "description": ""
                    }
                },
                "minCpuPlatform": "",
                "oauthScopes": [],
                "serviceAccount": "",
                "shieldedInstanceConfig": {
                    "enableIntegrityMonitoring": False,
                    "enableSecureBoot": False
                },
                "upgradeSettings": {
                    "blueGreenSettings": {
                        "nodePoolSoakDuration": "",
                        "standardRolloutPolicy": {
                            "batchNodeCount": 0,
                            "batchPercentage": "",
                            "batchSoakDuration": ""
                        }
                    },
                    "maxSurge": 0,
                    "maxUnavailable": 0,
                    "strategy": ""
                }
            },
            "autoscalingProfile": "",
            "enableNodeAutoprovisioning": False,
            "resourceLimits": [
                {
                    "maximum": "",
                    "minimum": "",
                    "resourceType": ""
                }
            ]
        },
        "binaryAuthorization": {
            "enabled": False,
            "evaluationMode": ""
        },
        "clusterIpv4Cidr": "",
        "clusterTelemetry": { "type": "" },
        "conditions": [
            {
                "canonicalCode": "",
                "code": "",
                "message": ""
            }
        ],
        "confidentialNodes": { "enabled": False },
        "costManagementConfig": { "enabled": False },
        "createTime": "",
        "currentMasterVersion": "",
        "currentNodeCount": 0,
        "currentNodeVersion": "",
        "databaseEncryption": {
            "keyName": "",
            "state": ""
        },
        "defaultMaxPodsConstraint": { "maxPodsPerNode": "" },
        "description": "",
        "enableKubernetesAlpha": False,
        "enableTpu": False,
        "endpoint": "",
        "etag": "",
        "expireTime": "",
        "fleet": {
            "membership": "",
            "preRegistered": False,
            "project": ""
        },
        "id": "",
        "identityServiceConfig": { "enabled": False },
        "initialClusterVersion": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "ipAllocationPolicy": {
            "additionalPodRangesConfig": { "podRangeNames": [] },
            "allowRouteOverlap": False,
            "clusterIpv4Cidr": "",
            "clusterIpv4CidrBlock": "",
            "clusterSecondaryRangeName": "",
            "createSubnetwork": False,
            "ipv6AccessType": "",
            "nodeIpv4Cidr": "",
            "nodeIpv4CidrBlock": "",
            "podCidrOverprovisionConfig": { "disable": False },
            "servicesIpv4Cidr": "",
            "servicesIpv4CidrBlock": "",
            "servicesIpv6CidrBlock": "",
            "servicesSecondaryRangeName": "",
            "stackType": "",
            "subnetIpv6CidrBlock": "",
            "subnetworkName": "",
            "tpuIpv4CidrBlock": "",
            "useIpAliases": False,
            "useRoutes": False
        },
        "labelFingerprint": "",
        "legacyAbac": { "enabled": False },
        "location": "",
        "locations": [],
        "loggingConfig": { "componentConfig": { "enableComponents": [] } },
        "loggingService": "",
        "maintenancePolicy": {
            "resourceVersion": "",
            "window": {
                "dailyMaintenanceWindow": {
                    "duration": "",
                    "startTime": ""
                },
                "maintenanceExclusions": {},
                "recurringWindow": {
                    "recurrence": "",
                    "window": {
                        "endTime": "",
                        "maintenanceExclusionOptions": { "scope": "" },
                        "startTime": ""
                    }
                }
            }
        },
        "master": {},
        "masterAuth": {
            "clientCertificate": "",
            "clientCertificateConfig": { "issueClientCertificate": False },
            "clientKey": "",
            "clusterCaCertificate": "",
            "password": "",
            "username": ""
        },
        "masterAuthorizedNetworksConfig": {
            "cidrBlocks": [
                {
                    "cidrBlock": "",
                    "displayName": ""
                }
            ],
            "enabled": False,
            "gcpPublicCidrsAccessEnabled": False
        },
        "masterIpv4CidrBlock": "",
        "meshCertificates": { "enableCertificates": False },
        "monitoringConfig": {
            "componentConfig": { "enableComponents": [] },
            "managedPrometheusConfig": { "enabled": False }
        },
        "monitoringService": "",
        "name": "",
        "network": "",
        "networkConfig": {
            "datapathProvider": "",
            "defaultSnatStatus": { "disabled": False },
            "dnsConfig": {
                "clusterDns": "",
                "clusterDnsDomain": "",
                "clusterDnsScope": ""
            },
            "enableIntraNodeVisibility": False,
            "enableL4ilbSubsetting": False,
            "gatewayApiConfig": { "channel": "" },
            "network": "",
            "privateIpv6GoogleAccess": "",
            "serviceExternalIpsConfig": { "enabled": False },
            "subnetwork": ""
        },
        "networkPolicy": {
            "enabled": False,
            "provider": ""
        },
        "nodeConfig": {
            "accelerators": [
                {
                    "acceleratorCount": "",
                    "acceleratorType": "",
                    "gpuPartitionSize": "",
                    "gpuSharingConfig": {
                        "gpuSharingStrategy": "",
                        "maxSharedClientsPerGpu": ""
                    },
                    "maxTimeSharedClientsPerGpu": ""
                }
            ],
            "advancedMachineFeatures": { "threadsPerCore": "" },
            "bootDiskKmsKey": "",
            "confidentialNodes": {},
            "diskSizeGb": 0,
            "diskType": "",
            "ephemeralStorageConfig": { "localSsdCount": 0 },
            "ephemeralStorageLocalSsdConfig": { "localSsdCount": 0 },
            "fastSocket": { "enabled": False },
            "gcfsConfig": { "enabled": False },
            "gvnic": { "enabled": False },
            "imageType": "",
            "kubeletConfig": {
                "cpuCfsQuota": False,
                "cpuCfsQuotaPeriod": "",
                "cpuManagerPolicy": "",
                "podPidsLimit": ""
            },
            "labels": {},
            "linuxNodeConfig": {
                "cgroupMode": "",
                "sysctls": {}
            },
            "localNvmeSsdBlockConfig": { "localSsdCount": 0 },
            "localSsdCount": 0,
            "loggingConfig": { "variantConfig": { "variant": "" } },
            "machineType": "",
            "metadata": {},
            "minCpuPlatform": "",
            "nodeGroup": "",
            "oauthScopes": [],
            "preemptible": False,
            "reservationAffinity": {
                "consumeReservationType": "",
                "key": "",
                "values": []
            },
            "resourceLabels": {},
            "sandboxConfig": {
                "sandboxType": "",
                "type": ""
            },
            "serviceAccount": "",
            "shieldedInstanceConfig": {},
            "spot": False,
            "tags": [],
            "taints": [
                {
                    "effect": "",
                    "key": "",
                    "value": ""
                }
            ],
            "windowsNodeConfig": { "osVersion": "" },
            "workloadMetadataConfig": {
                "mode": "",
                "nodeMetadata": ""
            }
        },
        "nodeIpv4CidrSize": 0,
        "nodePoolAutoConfig": { "networkTags": { "tags": [] } },
        "nodePoolDefaults": { "nodeConfigDefaults": {
                "gcfsConfig": {},
                "loggingConfig": {}
            } },
        "nodePools": [
            {
                "autoscaling": {
                    "autoprovisioned": False,
                    "enabled": False,
                    "locationPolicy": "",
                    "maxNodeCount": 0,
                    "minNodeCount": 0,
                    "totalMaxNodeCount": 0,
                    "totalMinNodeCount": 0
                },
                "conditions": [{}],
                "config": {},
                "etag": "",
                "initialNodeCount": 0,
                "instanceGroupUrls": [],
                "locations": [],
                "management": {},
                "maxPodsConstraint": {},
                "name": "",
                "networkConfig": {
                    "createPodRange": False,
                    "enablePrivateNodes": False,
                    "networkPerformanceConfig": {
                        "externalIpEgressBandwidthTier": "",
                        "totalEgressBandwidthTier": ""
                    },
                    "podCidrOverprovisionConfig": {},
                    "podIpv4CidrBlock": "",
                    "podRange": ""
                },
                "placementPolicy": { "type": "" },
                "podIpv4CidrSize": 0,
                "selfLink": "",
                "status": "",
                "statusMessage": "",
                "updateInfo": { "blueGreenInfo": {
                        "blueInstanceGroupUrls": [],
                        "bluePoolDeletionStartTime": "",
                        "greenInstanceGroupUrls": [],
                        "greenPoolVersion": "",
                        "phase": ""
                    } },
                "upgradeSettings": {},
                "version": ""
            }
        ],
        "notificationConfig": { "pubsub": {
                "enabled": False,
                "filter": { "eventType": [] },
                "topic": ""
            } },
        "podSecurityPolicyConfig": { "enabled": False },
        "privateCluster": False,
        "privateClusterConfig": {
            "enablePrivateEndpoint": False,
            "enablePrivateNodes": False,
            "masterGlobalAccessConfig": { "enabled": False },
            "masterIpv4CidrBlock": "",
            "peeringName": "",
            "privateEndpoint": "",
            "privateEndpointSubnetwork": "",
            "publicEndpoint": ""
        },
        "protectConfig": {
            "workloadConfig": { "auditMode": "" },
            "workloadVulnerabilityMode": ""
        },
        "releaseChannel": { "channel": "" },
        "resourceLabels": {},
        "resourceUsageExportConfig": {
            "bigqueryDestination": { "datasetId": "" },
            "consumptionMeteringConfig": { "enabled": False },
            "enableNetworkEgressMetering": False
        },
        "selfLink": "",
        "servicesIpv4Cidr": "",
        "shieldedNodes": { "enabled": False },
        "status": "",
        "statusMessage": "",
        "subnetwork": "",
        "tpuConfig": {
            "enabled": False,
            "ipv4CidrBlock": "",
            "useServiceNetworking": False
        },
        "tpuIpv4CidrBlock": "",
        "verticalPodAutoscaling": { "enabled": False },
        "workloadAltsConfig": { "enableAlts": False },
        "workloadCertificates": { "enableCertificates": False },
        "workloadIdentityConfig": {
            "identityNamespace": "",
            "identityProvider": "",
            "workloadPool": ""
        },
        "zone": ""
    },
    "parent": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters"

payload <- "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters")

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  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters') do |req|
  req.body = "{\n  \"cluster\": {\n    \"addonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"authenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"autopilot\": {\n      \"enabled\": false\n    },\n    \"autoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"binaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"clusterIpv4Cidr\": \"\",\n    \"clusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"confidentialNodes\": {\n      \"enabled\": false\n    },\n    \"costManagementConfig\": {\n      \"enabled\": false\n    },\n    \"createTime\": \"\",\n    \"currentMasterVersion\": \"\",\n    \"currentNodeCount\": 0,\n    \"currentNodeVersion\": \"\",\n    \"databaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"defaultMaxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"description\": \"\",\n    \"enableKubernetesAlpha\": false,\n    \"enableTpu\": false,\n    \"endpoint\": \"\",\n    \"etag\": \"\",\n    \"expireTime\": \"\",\n    \"fleet\": {\n      \"membership\": \"\",\n      \"preRegistered\": false,\n      \"project\": \"\"\n    },\n    \"id\": \"\",\n    \"identityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"initialClusterVersion\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"ipAllocationPolicy\": {\n      \"additionalPodRangesConfig\": {\n        \"podRangeNames\": []\n      },\n      \"allowRouteOverlap\": false,\n      \"clusterIpv4Cidr\": \"\",\n      \"clusterIpv4CidrBlock\": \"\",\n      \"clusterSecondaryRangeName\": \"\",\n      \"createSubnetwork\": false,\n      \"ipv6AccessType\": \"\",\n      \"nodeIpv4Cidr\": \"\",\n      \"nodeIpv4CidrBlock\": \"\",\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"servicesIpv4Cidr\": \"\",\n      \"servicesIpv4CidrBlock\": \"\",\n      \"servicesIpv6CidrBlock\": \"\",\n      \"servicesSecondaryRangeName\": \"\",\n      \"stackType\": \"\",\n      \"subnetIpv6CidrBlock\": \"\",\n      \"subnetworkName\": \"\",\n      \"tpuIpv4CidrBlock\": \"\",\n      \"useIpAliases\": false,\n      \"useRoutes\": false\n    },\n    \"labelFingerprint\": \"\",\n    \"legacyAbac\": {\n      \"enabled\": false\n    },\n    \"location\": \"\",\n    \"locations\": [],\n    \"loggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"loggingService\": \"\",\n    \"maintenancePolicy\": {\n      \"resourceVersion\": \"\",\n      \"window\": {\n        \"dailyMaintenanceWindow\": {\n          \"duration\": \"\",\n          \"startTime\": \"\"\n        },\n        \"maintenanceExclusions\": {},\n        \"recurringWindow\": {\n          \"recurrence\": \"\",\n          \"window\": {\n            \"endTime\": \"\",\n            \"maintenanceExclusionOptions\": {\n              \"scope\": \"\"\n            },\n            \"startTime\": \"\"\n          }\n        }\n      }\n    },\n    \"master\": {},\n    \"masterAuth\": {\n      \"clientCertificate\": \"\",\n      \"clientCertificateConfig\": {\n        \"issueClientCertificate\": false\n      },\n      \"clientKey\": \"\",\n      \"clusterCaCertificate\": \"\",\n      \"password\": \"\",\n      \"username\": \"\"\n    },\n    \"masterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"masterIpv4CidrBlock\": \"\",\n    \"meshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"monitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"monitoringService\": \"\",\n    \"name\": \"\",\n    \"network\": \"\",\n    \"networkConfig\": {\n      \"datapathProvider\": \"\",\n      \"defaultSnatStatus\": {\n        \"disabled\": false\n      },\n      \"dnsConfig\": {\n        \"clusterDns\": \"\",\n        \"clusterDnsDomain\": \"\",\n        \"clusterDnsScope\": \"\"\n      },\n      \"enableIntraNodeVisibility\": false,\n      \"enableL4ilbSubsetting\": false,\n      \"gatewayApiConfig\": {\n        \"channel\": \"\"\n      },\n      \"network\": \"\",\n      \"privateIpv6GoogleAccess\": \"\",\n      \"serviceExternalIpsConfig\": {\n        \"enabled\": false\n      },\n      \"subnetwork\": \"\"\n    },\n    \"networkPolicy\": {\n      \"enabled\": false,\n      \"provider\": \"\"\n    },\n    \"nodeConfig\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {},\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {},\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"nodeIpv4CidrSize\": 0,\n    \"nodePoolAutoConfig\": {\n      \"networkTags\": {\n        \"tags\": []\n      }\n    },\n    \"nodePoolDefaults\": {\n      \"nodeConfigDefaults\": {\n        \"gcfsConfig\": {},\n        \"loggingConfig\": {}\n      }\n    },\n    \"nodePools\": [\n      {\n        \"autoscaling\": {\n          \"autoprovisioned\": false,\n          \"enabled\": false,\n          \"locationPolicy\": \"\",\n          \"maxNodeCount\": 0,\n          \"minNodeCount\": 0,\n          \"totalMaxNodeCount\": 0,\n          \"totalMinNodeCount\": 0\n        },\n        \"conditions\": [\n          {}\n        ],\n        \"config\": {},\n        \"etag\": \"\",\n        \"initialNodeCount\": 0,\n        \"instanceGroupUrls\": [],\n        \"locations\": [],\n        \"management\": {},\n        \"maxPodsConstraint\": {},\n        \"name\": \"\",\n        \"networkConfig\": {\n          \"createPodRange\": false,\n          \"enablePrivateNodes\": false,\n          \"networkPerformanceConfig\": {\n            \"externalIpEgressBandwidthTier\": \"\",\n            \"totalEgressBandwidthTier\": \"\"\n          },\n          \"podCidrOverprovisionConfig\": {},\n          \"podIpv4CidrBlock\": \"\",\n          \"podRange\": \"\"\n        },\n        \"placementPolicy\": {\n          \"type\": \"\"\n        },\n        \"podIpv4CidrSize\": 0,\n        \"selfLink\": \"\",\n        \"status\": \"\",\n        \"statusMessage\": \"\",\n        \"updateInfo\": {\n          \"blueGreenInfo\": {\n            \"blueInstanceGroupUrls\": [],\n            \"bluePoolDeletionStartTime\": \"\",\n            \"greenInstanceGroupUrls\": [],\n            \"greenPoolVersion\": \"\",\n            \"phase\": \"\"\n          }\n        },\n        \"upgradeSettings\": {},\n        \"version\": \"\"\n      }\n    ],\n    \"notificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"podSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"privateCluster\": false,\n    \"privateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"protectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"releaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"resourceLabels\": {},\n    \"resourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"selfLink\": \"\",\n    \"servicesIpv4Cidr\": \"\",\n    \"shieldedNodes\": {\n      \"enabled\": false\n    },\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"subnetwork\": \"\",\n    \"tpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"tpuIpv4CidrBlock\": \"\",\n    \"verticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"workloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"workloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"workloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"zone\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters";

    let payload = json!({
        "cluster": json!({
            "addonsConfig": json!({
                "cloudRunConfig": json!({
                    "disabled": false,
                    "loadBalancerType": ""
                }),
                "configConnectorConfig": json!({"enabled": false}),
                "dnsCacheConfig": json!({"enabled": false}),
                "gcePersistentDiskCsiDriverConfig": json!({"enabled": false}),
                "gcpFilestoreCsiDriverConfig": json!({"enabled": false}),
                "gkeBackupAgentConfig": json!({"enabled": false}),
                "horizontalPodAutoscaling": json!({"disabled": false}),
                "httpLoadBalancing": json!({"disabled": false}),
                "istioConfig": json!({
                    "auth": "",
                    "disabled": false
                }),
                "kalmConfig": json!({"enabled": false}),
                "kubernetesDashboard": json!({"disabled": false}),
                "networkPolicyConfig": json!({"disabled": false})
            }),
            "authenticatorGroupsConfig": json!({
                "enabled": false,
                "securityGroup": ""
            }),
            "autopilot": json!({"enabled": false}),
            "autoscaling": json!({
                "autoprovisioningLocations": (),
                "autoprovisioningNodePoolDefaults": json!({
                    "bootDiskKmsKey": "",
                    "diskSizeGb": 0,
                    "diskType": "",
                    "imageType": "",
                    "management": json!({
                        "autoRepair": false,
                        "autoUpgrade": false,
                        "upgradeOptions": json!({
                            "autoUpgradeStartTime": "",
                            "description": ""
                        })
                    }),
                    "minCpuPlatform": "",
                    "oauthScopes": (),
                    "serviceAccount": "",
                    "shieldedInstanceConfig": json!({
                        "enableIntegrityMonitoring": false,
                        "enableSecureBoot": false
                    }),
                    "upgradeSettings": json!({
                        "blueGreenSettings": json!({
                            "nodePoolSoakDuration": "",
                            "standardRolloutPolicy": json!({
                                "batchNodeCount": 0,
                                "batchPercentage": "",
                                "batchSoakDuration": ""
                            })
                        }),
                        "maxSurge": 0,
                        "maxUnavailable": 0,
                        "strategy": ""
                    })
                }),
                "autoscalingProfile": "",
                "enableNodeAutoprovisioning": false,
                "resourceLimits": (
                    json!({
                        "maximum": "",
                        "minimum": "",
                        "resourceType": ""
                    })
                )
            }),
            "binaryAuthorization": json!({
                "enabled": false,
                "evaluationMode": ""
            }),
            "clusterIpv4Cidr": "",
            "clusterTelemetry": json!({"type": ""}),
            "conditions": (
                json!({
                    "canonicalCode": "",
                    "code": "",
                    "message": ""
                })
            ),
            "confidentialNodes": json!({"enabled": false}),
            "costManagementConfig": json!({"enabled": false}),
            "createTime": "",
            "currentMasterVersion": "",
            "currentNodeCount": 0,
            "currentNodeVersion": "",
            "databaseEncryption": json!({
                "keyName": "",
                "state": ""
            }),
            "defaultMaxPodsConstraint": json!({"maxPodsPerNode": ""}),
            "description": "",
            "enableKubernetesAlpha": false,
            "enableTpu": false,
            "endpoint": "",
            "etag": "",
            "expireTime": "",
            "fleet": json!({
                "membership": "",
                "preRegistered": false,
                "project": ""
            }),
            "id": "",
            "identityServiceConfig": json!({"enabled": false}),
            "initialClusterVersion": "",
            "initialNodeCount": 0,
            "instanceGroupUrls": (),
            "ipAllocationPolicy": json!({
                "additionalPodRangesConfig": json!({"podRangeNames": ()}),
                "allowRouteOverlap": false,
                "clusterIpv4Cidr": "",
                "clusterIpv4CidrBlock": "",
                "clusterSecondaryRangeName": "",
                "createSubnetwork": false,
                "ipv6AccessType": "",
                "nodeIpv4Cidr": "",
                "nodeIpv4CidrBlock": "",
                "podCidrOverprovisionConfig": json!({"disable": false}),
                "servicesIpv4Cidr": "",
                "servicesIpv4CidrBlock": "",
                "servicesIpv6CidrBlock": "",
                "servicesSecondaryRangeName": "",
                "stackType": "",
                "subnetIpv6CidrBlock": "",
                "subnetworkName": "",
                "tpuIpv4CidrBlock": "",
                "useIpAliases": false,
                "useRoutes": false
            }),
            "labelFingerprint": "",
            "legacyAbac": json!({"enabled": false}),
            "location": "",
            "locations": (),
            "loggingConfig": json!({"componentConfig": json!({"enableComponents": ()})}),
            "loggingService": "",
            "maintenancePolicy": json!({
                "resourceVersion": "",
                "window": json!({
                    "dailyMaintenanceWindow": json!({
                        "duration": "",
                        "startTime": ""
                    }),
                    "maintenanceExclusions": json!({}),
                    "recurringWindow": json!({
                        "recurrence": "",
                        "window": json!({
                            "endTime": "",
                            "maintenanceExclusionOptions": json!({"scope": ""}),
                            "startTime": ""
                        })
                    })
                })
            }),
            "master": json!({}),
            "masterAuth": json!({
                "clientCertificate": "",
                "clientCertificateConfig": json!({"issueClientCertificate": false}),
                "clientKey": "",
                "clusterCaCertificate": "",
                "password": "",
                "username": ""
            }),
            "masterAuthorizedNetworksConfig": json!({
                "cidrBlocks": (
                    json!({
                        "cidrBlock": "",
                        "displayName": ""
                    })
                ),
                "enabled": false,
                "gcpPublicCidrsAccessEnabled": false
            }),
            "masterIpv4CidrBlock": "",
            "meshCertificates": json!({"enableCertificates": false}),
            "monitoringConfig": json!({
                "componentConfig": json!({"enableComponents": ()}),
                "managedPrometheusConfig": json!({"enabled": false})
            }),
            "monitoringService": "",
            "name": "",
            "network": "",
            "networkConfig": json!({
                "datapathProvider": "",
                "defaultSnatStatus": json!({"disabled": false}),
                "dnsConfig": json!({
                    "clusterDns": "",
                    "clusterDnsDomain": "",
                    "clusterDnsScope": ""
                }),
                "enableIntraNodeVisibility": false,
                "enableL4ilbSubsetting": false,
                "gatewayApiConfig": json!({"channel": ""}),
                "network": "",
                "privateIpv6GoogleAccess": "",
                "serviceExternalIpsConfig": json!({"enabled": false}),
                "subnetwork": ""
            }),
            "networkPolicy": json!({
                "enabled": false,
                "provider": ""
            }),
            "nodeConfig": json!({
                "accelerators": (
                    json!({
                        "acceleratorCount": "",
                        "acceleratorType": "",
                        "gpuPartitionSize": "",
                        "gpuSharingConfig": json!({
                            "gpuSharingStrategy": "",
                            "maxSharedClientsPerGpu": ""
                        }),
                        "maxTimeSharedClientsPerGpu": ""
                    })
                ),
                "advancedMachineFeatures": json!({"threadsPerCore": ""}),
                "bootDiskKmsKey": "",
                "confidentialNodes": json!({}),
                "diskSizeGb": 0,
                "diskType": "",
                "ephemeralStorageConfig": json!({"localSsdCount": 0}),
                "ephemeralStorageLocalSsdConfig": json!({"localSsdCount": 0}),
                "fastSocket": json!({"enabled": false}),
                "gcfsConfig": json!({"enabled": false}),
                "gvnic": json!({"enabled": false}),
                "imageType": "",
                "kubeletConfig": json!({
                    "cpuCfsQuota": false,
                    "cpuCfsQuotaPeriod": "",
                    "cpuManagerPolicy": "",
                    "podPidsLimit": ""
                }),
                "labels": json!({}),
                "linuxNodeConfig": json!({
                    "cgroupMode": "",
                    "sysctls": json!({})
                }),
                "localNvmeSsdBlockConfig": json!({"localSsdCount": 0}),
                "localSsdCount": 0,
                "loggingConfig": json!({"variantConfig": json!({"variant": ""})}),
                "machineType": "",
                "metadata": json!({}),
                "minCpuPlatform": "",
                "nodeGroup": "",
                "oauthScopes": (),
                "preemptible": false,
                "reservationAffinity": json!({
                    "consumeReservationType": "",
                    "key": "",
                    "values": ()
                }),
                "resourceLabels": json!({}),
                "sandboxConfig": json!({
                    "sandboxType": "",
                    "type": ""
                }),
                "serviceAccount": "",
                "shieldedInstanceConfig": json!({}),
                "spot": false,
                "tags": (),
                "taints": (
                    json!({
                        "effect": "",
                        "key": "",
                        "value": ""
                    })
                ),
                "windowsNodeConfig": json!({"osVersion": ""}),
                "workloadMetadataConfig": json!({
                    "mode": "",
                    "nodeMetadata": ""
                })
            }),
            "nodeIpv4CidrSize": 0,
            "nodePoolAutoConfig": json!({"networkTags": json!({"tags": ()})}),
            "nodePoolDefaults": json!({"nodeConfigDefaults": json!({
                    "gcfsConfig": json!({}),
                    "loggingConfig": json!({})
                })}),
            "nodePools": (
                json!({
                    "autoscaling": json!({
                        "autoprovisioned": false,
                        "enabled": false,
                        "locationPolicy": "",
                        "maxNodeCount": 0,
                        "minNodeCount": 0,
                        "totalMaxNodeCount": 0,
                        "totalMinNodeCount": 0
                    }),
                    "conditions": (json!({})),
                    "config": json!({}),
                    "etag": "",
                    "initialNodeCount": 0,
                    "instanceGroupUrls": (),
                    "locations": (),
                    "management": json!({}),
                    "maxPodsConstraint": json!({}),
                    "name": "",
                    "networkConfig": json!({
                        "createPodRange": false,
                        "enablePrivateNodes": false,
                        "networkPerformanceConfig": json!({
                            "externalIpEgressBandwidthTier": "",
                            "totalEgressBandwidthTier": ""
                        }),
                        "podCidrOverprovisionConfig": json!({}),
                        "podIpv4CidrBlock": "",
                        "podRange": ""
                    }),
                    "placementPolicy": json!({"type": ""}),
                    "podIpv4CidrSize": 0,
                    "selfLink": "",
                    "status": "",
                    "statusMessage": "",
                    "updateInfo": json!({"blueGreenInfo": json!({
                            "blueInstanceGroupUrls": (),
                            "bluePoolDeletionStartTime": "",
                            "greenInstanceGroupUrls": (),
                            "greenPoolVersion": "",
                            "phase": ""
                        })}),
                    "upgradeSettings": json!({}),
                    "version": ""
                })
            ),
            "notificationConfig": json!({"pubsub": json!({
                    "enabled": false,
                    "filter": json!({"eventType": ()}),
                    "topic": ""
                })}),
            "podSecurityPolicyConfig": json!({"enabled": false}),
            "privateCluster": false,
            "privateClusterConfig": json!({
                "enablePrivateEndpoint": false,
                "enablePrivateNodes": false,
                "masterGlobalAccessConfig": json!({"enabled": false}),
                "masterIpv4CidrBlock": "",
                "peeringName": "",
                "privateEndpoint": "",
                "privateEndpointSubnetwork": "",
                "publicEndpoint": ""
            }),
            "protectConfig": json!({
                "workloadConfig": json!({"auditMode": ""}),
                "workloadVulnerabilityMode": ""
            }),
            "releaseChannel": json!({"channel": ""}),
            "resourceLabels": json!({}),
            "resourceUsageExportConfig": json!({
                "bigqueryDestination": json!({"datasetId": ""}),
                "consumptionMeteringConfig": json!({"enabled": false}),
                "enableNetworkEgressMetering": false
            }),
            "selfLink": "",
            "servicesIpv4Cidr": "",
            "shieldedNodes": json!({"enabled": false}),
            "status": "",
            "statusMessage": "",
            "subnetwork": "",
            "tpuConfig": json!({
                "enabled": false,
                "ipv4CidrBlock": "",
                "useServiceNetworking": false
            }),
            "tpuIpv4CidrBlock": "",
            "verticalPodAutoscaling": json!({"enabled": false}),
            "workloadAltsConfig": json!({"enableAlts": false}),
            "workloadCertificates": json!({"enableCertificates": false}),
            "workloadIdentityConfig": json!({
                "identityNamespace": "",
                "identityProvider": "",
                "workloadPool": ""
            }),
            "zone": ""
        }),
        "parent": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters \
  --header 'content-type: application/json' \
  --data '{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "cluster": {
    "addonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "authenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "autopilot": {
      "enabled": false
    },
    "autoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "binaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "clusterIpv4Cidr": "",
    "clusterTelemetry": {
      "type": ""
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "confidentialNodes": {
      "enabled": false
    },
    "costManagementConfig": {
      "enabled": false
    },
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "defaultMaxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": {
      "membership": "",
      "preRegistered": false,
      "project": ""
    },
    "id": "",
    "identityServiceConfig": {
      "enabled": false
    },
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": {
      "additionalPodRangesConfig": {
        "podRangeNames": []
      },
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    },
    "labelFingerprint": "",
    "legacyAbac": {
      "enabled": false
    },
    "location": "",
    "locations": [],
    "loggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "loggingService": "",
    "maintenancePolicy": {
      "resourceVersion": "",
      "window": {
        "dailyMaintenanceWindow": {
          "duration": "",
          "startTime": ""
        },
        "maintenanceExclusions": {},
        "recurringWindow": {
          "recurrence": "",
          "window": {
            "endTime": "",
            "maintenanceExclusionOptions": {
              "scope": ""
            },
            "startTime": ""
          }
        }
      }
    },
    "master": {},
    "masterAuth": {
      "clientCertificate": "",
      "clientCertificateConfig": {
        "issueClientCertificate": false
      },
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    },
    "masterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "masterIpv4CidrBlock": "",
    "meshCertificates": {
      "enableCertificates": false
    },
    "monitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": {
      "datapathProvider": "",
      "defaultSnatStatus": {
        "disabled": false
      },
      "dnsConfig": {
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      },
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": {
        "channel": ""
      },
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": {
        "enabled": false
      },
      "subnetwork": ""
    },
    "networkPolicy": {
      "enabled": false,
      "provider": ""
    },
    "nodeConfig": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {},
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {},
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": {
      "networkTags": {
        "tags": []
      }
    },
    "nodePoolDefaults": {
      "nodeConfigDefaults": {
        "gcfsConfig": {},
        "loggingConfig": {}
      }
    },
    "nodePools": [
      {
        "autoscaling": {
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        },
        "conditions": [
          {}
        ],
        "config": {},
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {},
        "maxPodsConstraint": {},
        "name": "",
        "networkConfig": {
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          },
          "podCidrOverprovisionConfig": {},
          "podIpv4CidrBlock": "",
          "podRange": ""
        },
        "placementPolicy": {
          "type": ""
        },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": {
          "blueGreenInfo": {
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          }
        },
        "upgradeSettings": {},
        "version": ""
      }
    ],
    "notificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "podSecurityPolicyConfig": {
      "enabled": false
    },
    "privateCluster": false,
    "privateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "protectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "releaseChannel": {
      "channel": ""
    },
    "resourceLabels": {},
    "resourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": {
      "enabled": false
    },
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": {
      "enabled": false
    },
    "workloadAltsConfig": {
      "enableAlts": false
    },
    "workloadCertificates": {
      "enableCertificates": false
    },
    "workloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "zone": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "cluster": {\n    "addonsConfig": {\n      "cloudRunConfig": {\n        "disabled": false,\n        "loadBalancerType": ""\n      },\n      "configConnectorConfig": {\n        "enabled": false\n      },\n      "dnsCacheConfig": {\n        "enabled": false\n      },\n      "gcePersistentDiskCsiDriverConfig": {\n        "enabled": false\n      },\n      "gcpFilestoreCsiDriverConfig": {\n        "enabled": false\n      },\n      "gkeBackupAgentConfig": {\n        "enabled": false\n      },\n      "horizontalPodAutoscaling": {\n        "disabled": false\n      },\n      "httpLoadBalancing": {\n        "disabled": false\n      },\n      "istioConfig": {\n        "auth": "",\n        "disabled": false\n      },\n      "kalmConfig": {\n        "enabled": false\n      },\n      "kubernetesDashboard": {\n        "disabled": false\n      },\n      "networkPolicyConfig": {\n        "disabled": false\n      }\n    },\n    "authenticatorGroupsConfig": {\n      "enabled": false,\n      "securityGroup": ""\n    },\n    "autopilot": {\n      "enabled": false\n    },\n    "autoscaling": {\n      "autoprovisioningLocations": [],\n      "autoprovisioningNodePoolDefaults": {\n        "bootDiskKmsKey": "",\n        "diskSizeGb": 0,\n        "diskType": "",\n        "imageType": "",\n        "management": {\n          "autoRepair": false,\n          "autoUpgrade": false,\n          "upgradeOptions": {\n            "autoUpgradeStartTime": "",\n            "description": ""\n          }\n        },\n        "minCpuPlatform": "",\n        "oauthScopes": [],\n        "serviceAccount": "",\n        "shieldedInstanceConfig": {\n          "enableIntegrityMonitoring": false,\n          "enableSecureBoot": false\n        },\n        "upgradeSettings": {\n          "blueGreenSettings": {\n            "nodePoolSoakDuration": "",\n            "standardRolloutPolicy": {\n              "batchNodeCount": 0,\n              "batchPercentage": "",\n              "batchSoakDuration": ""\n            }\n          },\n          "maxSurge": 0,\n          "maxUnavailable": 0,\n          "strategy": ""\n        }\n      },\n      "autoscalingProfile": "",\n      "enableNodeAutoprovisioning": false,\n      "resourceLimits": [\n        {\n          "maximum": "",\n          "minimum": "",\n          "resourceType": ""\n        }\n      ]\n    },\n    "binaryAuthorization": {\n      "enabled": false,\n      "evaluationMode": ""\n    },\n    "clusterIpv4Cidr": "",\n    "clusterTelemetry": {\n      "type": ""\n    },\n    "conditions": [\n      {\n        "canonicalCode": "",\n        "code": "",\n        "message": ""\n      }\n    ],\n    "confidentialNodes": {\n      "enabled": false\n    },\n    "costManagementConfig": {\n      "enabled": false\n    },\n    "createTime": "",\n    "currentMasterVersion": "",\n    "currentNodeCount": 0,\n    "currentNodeVersion": "",\n    "databaseEncryption": {\n      "keyName": "",\n      "state": ""\n    },\n    "defaultMaxPodsConstraint": {\n      "maxPodsPerNode": ""\n    },\n    "description": "",\n    "enableKubernetesAlpha": false,\n    "enableTpu": false,\n    "endpoint": "",\n    "etag": "",\n    "expireTime": "",\n    "fleet": {\n      "membership": "",\n      "preRegistered": false,\n      "project": ""\n    },\n    "id": "",\n    "identityServiceConfig": {\n      "enabled": false\n    },\n    "initialClusterVersion": "",\n    "initialNodeCount": 0,\n    "instanceGroupUrls": [],\n    "ipAllocationPolicy": {\n      "additionalPodRangesConfig": {\n        "podRangeNames": []\n      },\n      "allowRouteOverlap": false,\n      "clusterIpv4Cidr": "",\n      "clusterIpv4CidrBlock": "",\n      "clusterSecondaryRangeName": "",\n      "createSubnetwork": false,\n      "ipv6AccessType": "",\n      "nodeIpv4Cidr": "",\n      "nodeIpv4CidrBlock": "",\n      "podCidrOverprovisionConfig": {\n        "disable": false\n      },\n      "servicesIpv4Cidr": "",\n      "servicesIpv4CidrBlock": "",\n      "servicesIpv6CidrBlock": "",\n      "servicesSecondaryRangeName": "",\n      "stackType": "",\n      "subnetIpv6CidrBlock": "",\n      "subnetworkName": "",\n      "tpuIpv4CidrBlock": "",\n      "useIpAliases": false,\n      "useRoutes": false\n    },\n    "labelFingerprint": "",\n    "legacyAbac": {\n      "enabled": false\n    },\n    "location": "",\n    "locations": [],\n    "loggingConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      }\n    },\n    "loggingService": "",\n    "maintenancePolicy": {\n      "resourceVersion": "",\n      "window": {\n        "dailyMaintenanceWindow": {\n          "duration": "",\n          "startTime": ""\n        },\n        "maintenanceExclusions": {},\n        "recurringWindow": {\n          "recurrence": "",\n          "window": {\n            "endTime": "",\n            "maintenanceExclusionOptions": {\n              "scope": ""\n            },\n            "startTime": ""\n          }\n        }\n      }\n    },\n    "master": {},\n    "masterAuth": {\n      "clientCertificate": "",\n      "clientCertificateConfig": {\n        "issueClientCertificate": false\n      },\n      "clientKey": "",\n      "clusterCaCertificate": "",\n      "password": "",\n      "username": ""\n    },\n    "masterAuthorizedNetworksConfig": {\n      "cidrBlocks": [\n        {\n          "cidrBlock": "",\n          "displayName": ""\n        }\n      ],\n      "enabled": false,\n      "gcpPublicCidrsAccessEnabled": false\n    },\n    "masterIpv4CidrBlock": "",\n    "meshCertificates": {\n      "enableCertificates": false\n    },\n    "monitoringConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      },\n      "managedPrometheusConfig": {\n        "enabled": false\n      }\n    },\n    "monitoringService": "",\n    "name": "",\n    "network": "",\n    "networkConfig": {\n      "datapathProvider": "",\n      "defaultSnatStatus": {\n        "disabled": false\n      },\n      "dnsConfig": {\n        "clusterDns": "",\n        "clusterDnsDomain": "",\n        "clusterDnsScope": ""\n      },\n      "enableIntraNodeVisibility": false,\n      "enableL4ilbSubsetting": false,\n      "gatewayApiConfig": {\n        "channel": ""\n      },\n      "network": "",\n      "privateIpv6GoogleAccess": "",\n      "serviceExternalIpsConfig": {\n        "enabled": false\n      },\n      "subnetwork": ""\n    },\n    "networkPolicy": {\n      "enabled": false,\n      "provider": ""\n    },\n    "nodeConfig": {\n      "accelerators": [\n        {\n          "acceleratorCount": "",\n          "acceleratorType": "",\n          "gpuPartitionSize": "",\n          "gpuSharingConfig": {\n            "gpuSharingStrategy": "",\n            "maxSharedClientsPerGpu": ""\n          },\n          "maxTimeSharedClientsPerGpu": ""\n        }\n      ],\n      "advancedMachineFeatures": {\n        "threadsPerCore": ""\n      },\n      "bootDiskKmsKey": "",\n      "confidentialNodes": {},\n      "diskSizeGb": 0,\n      "diskType": "",\n      "ephemeralStorageConfig": {\n        "localSsdCount": 0\n      },\n      "ephemeralStorageLocalSsdConfig": {\n        "localSsdCount": 0\n      },\n      "fastSocket": {\n        "enabled": false\n      },\n      "gcfsConfig": {\n        "enabled": false\n      },\n      "gvnic": {\n        "enabled": false\n      },\n      "imageType": "",\n      "kubeletConfig": {\n        "cpuCfsQuota": false,\n        "cpuCfsQuotaPeriod": "",\n        "cpuManagerPolicy": "",\n        "podPidsLimit": ""\n      },\n      "labels": {},\n      "linuxNodeConfig": {\n        "cgroupMode": "",\n        "sysctls": {}\n      },\n      "localNvmeSsdBlockConfig": {\n        "localSsdCount": 0\n      },\n      "localSsdCount": 0,\n      "loggingConfig": {\n        "variantConfig": {\n          "variant": ""\n        }\n      },\n      "machineType": "",\n      "metadata": {},\n      "minCpuPlatform": "",\n      "nodeGroup": "",\n      "oauthScopes": [],\n      "preemptible": false,\n      "reservationAffinity": {\n        "consumeReservationType": "",\n        "key": "",\n        "values": []\n      },\n      "resourceLabels": {},\n      "sandboxConfig": {\n        "sandboxType": "",\n        "type": ""\n      },\n      "serviceAccount": "",\n      "shieldedInstanceConfig": {},\n      "spot": false,\n      "tags": [],\n      "taints": [\n        {\n          "effect": "",\n          "key": "",\n          "value": ""\n        }\n      ],\n      "windowsNodeConfig": {\n        "osVersion": ""\n      },\n      "workloadMetadataConfig": {\n        "mode": "",\n        "nodeMetadata": ""\n      }\n    },\n    "nodeIpv4CidrSize": 0,\n    "nodePoolAutoConfig": {\n      "networkTags": {\n        "tags": []\n      }\n    },\n    "nodePoolDefaults": {\n      "nodeConfigDefaults": {\n        "gcfsConfig": {},\n        "loggingConfig": {}\n      }\n    },\n    "nodePools": [\n      {\n        "autoscaling": {\n          "autoprovisioned": false,\n          "enabled": false,\n          "locationPolicy": "",\n          "maxNodeCount": 0,\n          "minNodeCount": 0,\n          "totalMaxNodeCount": 0,\n          "totalMinNodeCount": 0\n        },\n        "conditions": [\n          {}\n        ],\n        "config": {},\n        "etag": "",\n        "initialNodeCount": 0,\n        "instanceGroupUrls": [],\n        "locations": [],\n        "management": {},\n        "maxPodsConstraint": {},\n        "name": "",\n        "networkConfig": {\n          "createPodRange": false,\n          "enablePrivateNodes": false,\n          "networkPerformanceConfig": {\n            "externalIpEgressBandwidthTier": "",\n            "totalEgressBandwidthTier": ""\n          },\n          "podCidrOverprovisionConfig": {},\n          "podIpv4CidrBlock": "",\n          "podRange": ""\n        },\n        "placementPolicy": {\n          "type": ""\n        },\n        "podIpv4CidrSize": 0,\n        "selfLink": "",\n        "status": "",\n        "statusMessage": "",\n        "updateInfo": {\n          "blueGreenInfo": {\n            "blueInstanceGroupUrls": [],\n            "bluePoolDeletionStartTime": "",\n            "greenInstanceGroupUrls": [],\n            "greenPoolVersion": "",\n            "phase": ""\n          }\n        },\n        "upgradeSettings": {},\n        "version": ""\n      }\n    ],\n    "notificationConfig": {\n      "pubsub": {\n        "enabled": false,\n        "filter": {\n          "eventType": []\n        },\n        "topic": ""\n      }\n    },\n    "podSecurityPolicyConfig": {\n      "enabled": false\n    },\n    "privateCluster": false,\n    "privateClusterConfig": {\n      "enablePrivateEndpoint": false,\n      "enablePrivateNodes": false,\n      "masterGlobalAccessConfig": {\n        "enabled": false\n      },\n      "masterIpv4CidrBlock": "",\n      "peeringName": "",\n      "privateEndpoint": "",\n      "privateEndpointSubnetwork": "",\n      "publicEndpoint": ""\n    },\n    "protectConfig": {\n      "workloadConfig": {\n        "auditMode": ""\n      },\n      "workloadVulnerabilityMode": ""\n    },\n    "releaseChannel": {\n      "channel": ""\n    },\n    "resourceLabels": {},\n    "resourceUsageExportConfig": {\n      "bigqueryDestination": {\n        "datasetId": ""\n      },\n      "consumptionMeteringConfig": {\n        "enabled": false\n      },\n      "enableNetworkEgressMetering": false\n    },\n    "selfLink": "",\n    "servicesIpv4Cidr": "",\n    "shieldedNodes": {\n      "enabled": false\n    },\n    "status": "",\n    "statusMessage": "",\n    "subnetwork": "",\n    "tpuConfig": {\n      "enabled": false,\n      "ipv4CidrBlock": "",\n      "useServiceNetworking": false\n    },\n    "tpuIpv4CidrBlock": "",\n    "verticalPodAutoscaling": {\n      "enabled": false\n    },\n    "workloadAltsConfig": {\n      "enableAlts": false\n    },\n    "workloadCertificates": {\n      "enableCertificates": false\n    },\n    "workloadIdentityConfig": {\n      "identityNamespace": "",\n      "identityProvider": "",\n      "workloadPool": ""\n    },\n    "zone": ""\n  },\n  "parent": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "cluster": [
    "addonsConfig": [
      "cloudRunConfig": [
        "disabled": false,
        "loadBalancerType": ""
      ],
      "configConnectorConfig": ["enabled": false],
      "dnsCacheConfig": ["enabled": false],
      "gcePersistentDiskCsiDriverConfig": ["enabled": false],
      "gcpFilestoreCsiDriverConfig": ["enabled": false],
      "gkeBackupAgentConfig": ["enabled": false],
      "horizontalPodAutoscaling": ["disabled": false],
      "httpLoadBalancing": ["disabled": false],
      "istioConfig": [
        "auth": "",
        "disabled": false
      ],
      "kalmConfig": ["enabled": false],
      "kubernetesDashboard": ["disabled": false],
      "networkPolicyConfig": ["disabled": false]
    ],
    "authenticatorGroupsConfig": [
      "enabled": false,
      "securityGroup": ""
    ],
    "autopilot": ["enabled": false],
    "autoscaling": [
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": [
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": [
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": [
            "autoUpgradeStartTime": "",
            "description": ""
          ]
        ],
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": [
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        ],
        "upgradeSettings": [
          "blueGreenSettings": [
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": [
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            ]
          ],
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        ]
      ],
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        [
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        ]
      ]
    ],
    "binaryAuthorization": [
      "enabled": false,
      "evaluationMode": ""
    ],
    "clusterIpv4Cidr": "",
    "clusterTelemetry": ["type": ""],
    "conditions": [
      [
        "canonicalCode": "",
        "code": "",
        "message": ""
      ]
    ],
    "confidentialNodes": ["enabled": false],
    "costManagementConfig": ["enabled": false],
    "createTime": "",
    "currentMasterVersion": "",
    "currentNodeCount": 0,
    "currentNodeVersion": "",
    "databaseEncryption": [
      "keyName": "",
      "state": ""
    ],
    "defaultMaxPodsConstraint": ["maxPodsPerNode": ""],
    "description": "",
    "enableKubernetesAlpha": false,
    "enableTpu": false,
    "endpoint": "",
    "etag": "",
    "expireTime": "",
    "fleet": [
      "membership": "",
      "preRegistered": false,
      "project": ""
    ],
    "id": "",
    "identityServiceConfig": ["enabled": false],
    "initialClusterVersion": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "ipAllocationPolicy": [
      "additionalPodRangesConfig": ["podRangeNames": []],
      "allowRouteOverlap": false,
      "clusterIpv4Cidr": "",
      "clusterIpv4CidrBlock": "",
      "clusterSecondaryRangeName": "",
      "createSubnetwork": false,
      "ipv6AccessType": "",
      "nodeIpv4Cidr": "",
      "nodeIpv4CidrBlock": "",
      "podCidrOverprovisionConfig": ["disable": false],
      "servicesIpv4Cidr": "",
      "servicesIpv4CidrBlock": "",
      "servicesIpv6CidrBlock": "",
      "servicesSecondaryRangeName": "",
      "stackType": "",
      "subnetIpv6CidrBlock": "",
      "subnetworkName": "",
      "tpuIpv4CidrBlock": "",
      "useIpAliases": false,
      "useRoutes": false
    ],
    "labelFingerprint": "",
    "legacyAbac": ["enabled": false],
    "location": "",
    "locations": [],
    "loggingConfig": ["componentConfig": ["enableComponents": []]],
    "loggingService": "",
    "maintenancePolicy": [
      "resourceVersion": "",
      "window": [
        "dailyMaintenanceWindow": [
          "duration": "",
          "startTime": ""
        ],
        "maintenanceExclusions": [],
        "recurringWindow": [
          "recurrence": "",
          "window": [
            "endTime": "",
            "maintenanceExclusionOptions": ["scope": ""],
            "startTime": ""
          ]
        ]
      ]
    ],
    "master": [],
    "masterAuth": [
      "clientCertificate": "",
      "clientCertificateConfig": ["issueClientCertificate": false],
      "clientKey": "",
      "clusterCaCertificate": "",
      "password": "",
      "username": ""
    ],
    "masterAuthorizedNetworksConfig": [
      "cidrBlocks": [
        [
          "cidrBlock": "",
          "displayName": ""
        ]
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    ],
    "masterIpv4CidrBlock": "",
    "meshCertificates": ["enableCertificates": false],
    "monitoringConfig": [
      "componentConfig": ["enableComponents": []],
      "managedPrometheusConfig": ["enabled": false]
    ],
    "monitoringService": "",
    "name": "",
    "network": "",
    "networkConfig": [
      "datapathProvider": "",
      "defaultSnatStatus": ["disabled": false],
      "dnsConfig": [
        "clusterDns": "",
        "clusterDnsDomain": "",
        "clusterDnsScope": ""
      ],
      "enableIntraNodeVisibility": false,
      "enableL4ilbSubsetting": false,
      "gatewayApiConfig": ["channel": ""],
      "network": "",
      "privateIpv6GoogleAccess": "",
      "serviceExternalIpsConfig": ["enabled": false],
      "subnetwork": ""
    ],
    "networkPolicy": [
      "enabled": false,
      "provider": ""
    ],
    "nodeConfig": [
      "accelerators": [
        [
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": [
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          ],
          "maxTimeSharedClientsPerGpu": ""
        ]
      ],
      "advancedMachineFeatures": ["threadsPerCore": ""],
      "bootDiskKmsKey": "",
      "confidentialNodes": [],
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": ["localSsdCount": 0],
      "ephemeralStorageLocalSsdConfig": ["localSsdCount": 0],
      "fastSocket": ["enabled": false],
      "gcfsConfig": ["enabled": false],
      "gvnic": ["enabled": false],
      "imageType": "",
      "kubeletConfig": [
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      ],
      "labels": [],
      "linuxNodeConfig": [
        "cgroupMode": "",
        "sysctls": []
      ],
      "localNvmeSsdBlockConfig": ["localSsdCount": 0],
      "localSsdCount": 0,
      "loggingConfig": ["variantConfig": ["variant": ""]],
      "machineType": "",
      "metadata": [],
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": [
        "consumeReservationType": "",
        "key": "",
        "values": []
      ],
      "resourceLabels": [],
      "sandboxConfig": [
        "sandboxType": "",
        "type": ""
      ],
      "serviceAccount": "",
      "shieldedInstanceConfig": [],
      "spot": false,
      "tags": [],
      "taints": [
        [
          "effect": "",
          "key": "",
          "value": ""
        ]
      ],
      "windowsNodeConfig": ["osVersion": ""],
      "workloadMetadataConfig": [
        "mode": "",
        "nodeMetadata": ""
      ]
    ],
    "nodeIpv4CidrSize": 0,
    "nodePoolAutoConfig": ["networkTags": ["tags": []]],
    "nodePoolDefaults": ["nodeConfigDefaults": [
        "gcfsConfig": [],
        "loggingConfig": []
      ]],
    "nodePools": [
      [
        "autoscaling": [
          "autoprovisioned": false,
          "enabled": false,
          "locationPolicy": "",
          "maxNodeCount": 0,
          "minNodeCount": 0,
          "totalMaxNodeCount": 0,
          "totalMinNodeCount": 0
        ],
        "conditions": [[]],
        "config": [],
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": [],
        "maxPodsConstraint": [],
        "name": "",
        "networkConfig": [
          "createPodRange": false,
          "enablePrivateNodes": false,
          "networkPerformanceConfig": [
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
          ],
          "podCidrOverprovisionConfig": [],
          "podIpv4CidrBlock": "",
          "podRange": ""
        ],
        "placementPolicy": ["type": ""],
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": ["blueGreenInfo": [
            "blueInstanceGroupUrls": [],
            "bluePoolDeletionStartTime": "",
            "greenInstanceGroupUrls": [],
            "greenPoolVersion": "",
            "phase": ""
          ]],
        "upgradeSettings": [],
        "version": ""
      ]
    ],
    "notificationConfig": ["pubsub": [
        "enabled": false,
        "filter": ["eventType": []],
        "topic": ""
      ]],
    "podSecurityPolicyConfig": ["enabled": false],
    "privateCluster": false,
    "privateClusterConfig": [
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": ["enabled": false],
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    ],
    "protectConfig": [
      "workloadConfig": ["auditMode": ""],
      "workloadVulnerabilityMode": ""
    ],
    "releaseChannel": ["channel": ""],
    "resourceLabels": [],
    "resourceUsageExportConfig": [
      "bigqueryDestination": ["datasetId": ""],
      "consumptionMeteringConfig": ["enabled": false],
      "enableNetworkEgressMetering": false
    ],
    "selfLink": "",
    "servicesIpv4Cidr": "",
    "shieldedNodes": ["enabled": false],
    "status": "",
    "statusMessage": "",
    "subnetwork": "",
    "tpuConfig": [
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    ],
    "tpuIpv4CidrBlock": "",
    "verticalPodAutoscaling": ["enabled": false],
    "workloadAltsConfig": ["enableAlts": false],
    "workloadCertificates": ["enableCertificates": false],
    "workloadIdentityConfig": [
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    ],
    "zone": ""
  ],
  "parent": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters")! 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 container.projects.zones.clusters.delete
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId
QUERY PARAMS

projectId
zone
clusterId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"

	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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"))
    .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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId',
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId",
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")

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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId";

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId
http DELETE {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")! 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 container.projects.zones.clusters.get
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId
QUERY PARAMS

projectId
zone
clusterId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"

	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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"))
    .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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId',
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId",
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")

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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId";

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId
http GET {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")! 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 container.projects.zones.clusters.legacyAbac
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac");

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  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac" {:content-type :json
                                                                                                                   :form-params {:clusterId ""
                                                                                                                                 :enabled false
                                                                                                                                 :name ""
                                                                                                                                 :projectId ""
                                                                                                                                 :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 88

{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  enabled: false,
  name: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', enabled: false, name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","enabled":false,"name":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "enabled": false,\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac',
  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({clusterId: '', enabled: false, name: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', enabled: false, name: '', projectId: '', zone: ''},
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  enabled: false,
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', enabled: false, name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","enabled":false,"name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"enabled": @NO,
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac",
  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([
    'clusterId' => '',
    'enabled' => null,
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac', [
  'body' => '{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'enabled' => null,
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'enabled' => null,
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac"

payload = {
    "clusterId": "",
    "enabled": False,
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac"

payload <- "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac")

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  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"enabled\": false,\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac";

    let payload = json!({
        "clusterId": "",
        "enabled": false,
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "enabled": false,\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "enabled": false,
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/legacyAbac")! 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 container.projects.zones.clusters.list
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters
QUERY PARAMS

projectId
zone
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters")
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters"

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}}/v1beta1/projects/:projectId/zones/:zone/clusters"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters"

	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/v1beta1/projects/:projectId/zones/:zone/clusters HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters"))
    .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}}/v1beta1/projects/:projectId/zones/:zone/clusters")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters")
  .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}}/v1beta1/projects/:projectId/zones/:zone/clusters');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters',
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters');

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}}/v1beta1/projects/:projectId/zones/:zone/clusters'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters",
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters")

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/v1beta1/projects/:projectId/zones/:zone/clusters') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters";

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters
http GET {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters")! 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 container.projects.zones.clusters.locations
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations");

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  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations" {:content-type :json
                                                                                                                  :form-params {:clusterId ""
                                                                                                                                :locations []
                                                                                                                                :name ""
                                                                                                                                :projectId ""
                                                                                                                                :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 87

{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  locations: [],
  name: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', locations: [], name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","locations":[],"name":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "locations": [],\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations',
  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({clusterId: '', locations: [], name: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', locations: [], name: '', projectId: '', zone: ''},
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  locations: [],
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', locations: [], name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","locations":[],"name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"locations": @[  ],
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations",
  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([
    'clusterId' => '',
    'locations' => [
        
    ],
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations', [
  'body' => '{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'locations' => [
    
  ],
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'locations' => [
    
  ],
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations"

payload = {
    "clusterId": "",
    "locations": [],
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations"

payload <- "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations")

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  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"locations\": [],\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations";

    let payload = json!({
        "clusterId": "",
        "locations": (),
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "locations": [],\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "locations": [],
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/locations")! 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 container.projects.zones.clusters.logging
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging");

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  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging" {:content-type :json
                                                                                                                :form-params {:clusterId ""
                                                                                                                              :loggingService ""
                                                                                                                              :name ""
                                                                                                                              :projectId ""
                                                                                                                              :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 92

{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  loggingService: '',
  name: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', loggingService: '', name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","loggingService":"","name":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "loggingService": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging',
  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({clusterId: '', loggingService: '', name: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', loggingService: '', name: '', projectId: '', zone: ''},
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  loggingService: '',
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', loggingService: '', name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","loggingService":"","name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"loggingService": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging",
  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([
    'clusterId' => '',
    'loggingService' => '',
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging', [
  'body' => '{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'loggingService' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'loggingService' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging"

payload = {
    "clusterId": "",
    "loggingService": "",
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging"

payload <- "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging")

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  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"loggingService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging";

    let payload = json!({
        "clusterId": "",
        "loggingService": "",
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "loggingService": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "loggingService": "",
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/logging")! 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 container.projects.zones.clusters.master
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master");

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  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master" {:content-type :json
                                                                                                               :form-params {:clusterId ""
                                                                                                                             :masterVersion ""
                                                                                                                             :name ""
                                                                                                                             :projectId ""
                                                                                                                             :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 91

{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  masterVersion: '',
  name: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', masterVersion: '', name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","masterVersion":"","name":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "masterVersion": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master',
  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({clusterId: '', masterVersion: '', name: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', masterVersion: '', name: '', projectId: '', zone: ''},
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  masterVersion: '',
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', masterVersion: '', name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","masterVersion":"","name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"masterVersion": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master",
  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([
    'clusterId' => '',
    'masterVersion' => '',
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master', [
  'body' => '{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'masterVersion' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'masterVersion' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master"

payload = {
    "clusterId": "",
    "masterVersion": "",
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master"

payload <- "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master")

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  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"masterVersion\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master";

    let payload = json!({
        "clusterId": "",
        "masterVersion": "",
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "masterVersion": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "masterVersion": "",
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/master")! 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 container.projects.zones.clusters.monitoring
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring");

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  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring" {:content-type :json
                                                                                                                   :form-params {:clusterId ""
                                                                                                                                 :monitoringService ""
                                                                                                                                 :name ""
                                                                                                                                 :projectId ""
                                                                                                                                 :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 95

{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  monitoringService: '',
  name: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', monitoringService: '', name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","monitoringService":"","name":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "monitoringService": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring',
  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({clusterId: '', monitoringService: '', name: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', monitoringService: '', name: '', projectId: '', zone: ''},
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  monitoringService: '',
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', monitoringService: '', name: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","monitoringService":"","name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"monitoringService": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring",
  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([
    'clusterId' => '',
    'monitoringService' => '',
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring', [
  'body' => '{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'monitoringService' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'monitoringService' => '',
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring"

payload = {
    "clusterId": "",
    "monitoringService": "",
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring"

payload <- "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring")

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  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"monitoringService\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring";

    let payload = json!({
        "clusterId": "",
        "monitoringService": "",
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "monitoringService": "",\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "monitoringService": "",
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/monitoring")! 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 container.projects.zones.clusters.nodePools.autoscaling
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling
QUERY PARAMS

projectId
zone
clusterId
nodePoolId
BODY json

{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling");

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  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling" {:content-type :json
                                                                                                                                          :form-params {:autoscaling {:autoprovisioned false
                                                                                                                                                                      :enabled false
                                                                                                                                                                      :locationPolicy ""
                                                                                                                                                                      :maxNodeCount 0
                                                                                                                                                                      :minNodeCount 0
                                                                                                                                                                      :totalMaxNodeCount 0
                                                                                                                                                                      :totalMinNodeCount 0}
                                                                                                                                                        :clusterId ""
                                                                                                                                                        :name ""
                                                                                                                                                        :nodePoolId ""
                                                                                                                                                        :projectId ""
                                                                                                                                                        :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling"),
    Content = new StringContent("{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling"

	payload := strings.NewReader("{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 291

{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling")
  .header("content-type", "application/json")
  .body("{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  autoscaling: {
    autoprovisioned: false,
    enabled: false,
    locationPolicy: '',
    maxNodeCount: 0,
    minNodeCount: 0,
    totalMaxNodeCount: 0,
    totalMinNodeCount: 0
  },
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling',
  headers: {'content-type': 'application/json'},
  data: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"clusterId":"","name":"","nodePoolId":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "autoscaling": {\n    "autoprovisioned": false,\n    "enabled": false,\n    "locationPolicy": "",\n    "maxNodeCount": 0,\n    "minNodeCount": 0,\n    "totalMaxNodeCount": 0,\n    "totalMinNodeCount": 0\n  },\n  "clusterId": "",\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling',
  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({
  autoscaling: {
    autoprovisioned: false,
    enabled: false,
    locationPolicy: '',
    maxNodeCount: 0,
    minNodeCount: 0,
    totalMaxNodeCount: 0,
    totalMinNodeCount: 0
  },
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling',
  headers: {'content-type': 'application/json'},
  body: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  autoscaling: {
    autoprovisioned: false,
    enabled: false,
    locationPolicy: '',
    maxNodeCount: 0,
    minNodeCount: 0,
    totalMaxNodeCount: 0,
    totalMinNodeCount: 0
  },
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling',
  headers: {'content-type': 'application/json'},
  data: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"clusterId":"","name":"","nodePoolId":"","projectId":"","zone":""}'
};

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 = @{ @"autoscaling": @{ @"autoprovisioned": @NO, @"enabled": @NO, @"locationPolicy": @"", @"maxNodeCount": @0, @"minNodeCount": @0, @"totalMaxNodeCount": @0, @"totalMinNodeCount": @0 },
                              @"clusterId": @"",
                              @"name": @"",
                              @"nodePoolId": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling",
  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([
    'autoscaling' => [
        'autoprovisioned' => null,
        'enabled' => null,
        'locationPolicy' => '',
        'maxNodeCount' => 0,
        'minNodeCount' => 0,
        'totalMaxNodeCount' => 0,
        'totalMinNodeCount' => 0
    ],
    'clusterId' => '',
    'name' => '',
    'nodePoolId' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling', [
  'body' => '{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'autoscaling' => [
    'autoprovisioned' => null,
    'enabled' => null,
    'locationPolicy' => '',
    'maxNodeCount' => 0,
    'minNodeCount' => 0,
    'totalMaxNodeCount' => 0,
    'totalMinNodeCount' => 0
  ],
  'clusterId' => '',
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'autoscaling' => [
    'autoprovisioned' => null,
    'enabled' => null,
    'locationPolicy' => '',
    'maxNodeCount' => 0,
    'minNodeCount' => 0,
    'totalMaxNodeCount' => 0,
    'totalMinNodeCount' => 0
  ],
  'clusterId' => '',
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling"

payload = {
    "autoscaling": {
        "autoprovisioned": False,
        "enabled": False,
        "locationPolicy": "",
        "maxNodeCount": 0,
        "minNodeCount": 0,
        "totalMaxNodeCount": 0,
        "totalMinNodeCount": 0
    },
    "clusterId": "",
    "name": "",
    "nodePoolId": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling"

payload <- "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling")

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  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling') do |req|
  req.body = "{\n  \"autoscaling\": {\n    \"autoprovisioned\": false,\n    \"enabled\": false,\n    \"locationPolicy\": \"\",\n    \"maxNodeCount\": 0,\n    \"minNodeCount\": 0,\n    \"totalMaxNodeCount\": 0,\n    \"totalMinNodeCount\": 0\n  },\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling";

    let payload = json!({
        "autoscaling": json!({
            "autoprovisioned": false,
            "enabled": false,
            "locationPolicy": "",
            "maxNodeCount": 0,
            "minNodeCount": 0,
            "totalMaxNodeCount": 0,
            "totalMinNodeCount": 0
        }),
        "clusterId": "",
        "name": "",
        "nodePoolId": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling \
  --header 'content-type: application/json' \
  --data '{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "autoscaling": {
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  },
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "autoscaling": {\n    "autoprovisioned": false,\n    "enabled": false,\n    "locationPolicy": "",\n    "maxNodeCount": 0,\n    "minNodeCount": 0,\n    "totalMaxNodeCount": 0,\n    "totalMinNodeCount": 0\n  },\n  "clusterId": "",\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "autoscaling": [
    "autoprovisioned": false,
    "enabled": false,
    "locationPolicy": "",
    "maxNodeCount": 0,
    "minNodeCount": 0,
    "totalMaxNodeCount": 0,
    "totalMinNodeCount": 0
  ],
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/autoscaling")! 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 container.projects.zones.clusters.nodePools.create
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools");

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  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools" {:content-type :json
                                                                                                                  :form-params {:clusterId ""
                                                                                                                                :nodePool {:autoscaling {:autoprovisioned false
                                                                                                                                                         :enabled false
                                                                                                                                                         :locationPolicy ""
                                                                                                                                                         :maxNodeCount 0
                                                                                                                                                         :minNodeCount 0
                                                                                                                                                         :totalMaxNodeCount 0
                                                                                                                                                         :totalMinNodeCount 0}
                                                                                                                                           :conditions [{:canonicalCode ""
                                                                                                                                                         :code ""
                                                                                                                                                         :message ""}]
                                                                                                                                           :config {:accelerators [{:acceleratorCount ""
                                                                                                                                                                    :acceleratorType ""
                                                                                                                                                                    :gpuPartitionSize ""
                                                                                                                                                                    :gpuSharingConfig {:gpuSharingStrategy ""
                                                                                                                                                                                       :maxSharedClientsPerGpu ""}
                                                                                                                                                                    :maxTimeSharedClientsPerGpu ""}]
                                                                                                                                                    :advancedMachineFeatures {:threadsPerCore ""}
                                                                                                                                                    :bootDiskKmsKey ""
                                                                                                                                                    :confidentialNodes {:enabled false}
                                                                                                                                                    :diskSizeGb 0
                                                                                                                                                    :diskType ""
                                                                                                                                                    :ephemeralStorageConfig {:localSsdCount 0}
                                                                                                                                                    :ephemeralStorageLocalSsdConfig {:localSsdCount 0}
                                                                                                                                                    :fastSocket {:enabled false}
                                                                                                                                                    :gcfsConfig {:enabled false}
                                                                                                                                                    :gvnic {:enabled false}
                                                                                                                                                    :imageType ""
                                                                                                                                                    :kubeletConfig {:cpuCfsQuota false
                                                                                                                                                                    :cpuCfsQuotaPeriod ""
                                                                                                                                                                    :cpuManagerPolicy ""
                                                                                                                                                                    :podPidsLimit ""}
                                                                                                                                                    :labels {}
                                                                                                                                                    :linuxNodeConfig {:cgroupMode ""
                                                                                                                                                                      :sysctls {}}
                                                                                                                                                    :localNvmeSsdBlockConfig {:localSsdCount 0}
                                                                                                                                                    :localSsdCount 0
                                                                                                                                                    :loggingConfig {:variantConfig {:variant ""}}
                                                                                                                                                    :machineType ""
                                                                                                                                                    :metadata {}
                                                                                                                                                    :minCpuPlatform ""
                                                                                                                                                    :nodeGroup ""
                                                                                                                                                    :oauthScopes []
                                                                                                                                                    :preemptible false
                                                                                                                                                    :reservationAffinity {:consumeReservationType ""
                                                                                                                                                                          :key ""
                                                                                                                                                                          :values []}
                                                                                                                                                    :resourceLabels {}
                                                                                                                                                    :sandboxConfig {:sandboxType ""
                                                                                                                                                                    :type ""}
                                                                                                                                                    :serviceAccount ""
                                                                                                                                                    :shieldedInstanceConfig {:enableIntegrityMonitoring false
                                                                                                                                                                             :enableSecureBoot false}
                                                                                                                                                    :spot false
                                                                                                                                                    :tags []
                                                                                                                                                    :taints [{:effect ""
                                                                                                                                                              :key ""
                                                                                                                                                              :value ""}]
                                                                                                                                                    :windowsNodeConfig {:osVersion ""}
                                                                                                                                                    :workloadMetadataConfig {:mode ""
                                                                                                                                                                             :nodeMetadata ""}}
                                                                                                                                           :etag ""
                                                                                                                                           :initialNodeCount 0
                                                                                                                                           :instanceGroupUrls []
                                                                                                                                           :locations []
                                                                                                                                           :management {:autoRepair false
                                                                                                                                                        :autoUpgrade false
                                                                                                                                                        :upgradeOptions {:autoUpgradeStartTime ""
                                                                                                                                                                         :description ""}}
                                                                                                                                           :maxPodsConstraint {:maxPodsPerNode ""}
                                                                                                                                           :name ""
                                                                                                                                           :networkConfig {:createPodRange false
                                                                                                                                                           :enablePrivateNodes false
                                                                                                                                                           :networkPerformanceConfig {:externalIpEgressBandwidthTier ""
                                                                                                                                                                                      :totalEgressBandwidthTier ""}
                                                                                                                                                           :podCidrOverprovisionConfig {:disable false}
                                                                                                                                                           :podIpv4CidrBlock ""
                                                                                                                                                           :podRange ""}
                                                                                                                                           :placementPolicy {:type ""}
                                                                                                                                           :podIpv4CidrSize 0
                                                                                                                                           :selfLink ""
                                                                                                                                           :status ""
                                                                                                                                           :statusMessage ""
                                                                                                                                           :updateInfo {:blueGreenInfo {:blueInstanceGroupUrls []
                                                                                                                                                                        :bluePoolDeletionStartTime ""
                                                                                                                                                                        :greenInstanceGroupUrls []
                                                                                                                                                                        :greenPoolVersion ""
                                                                                                                                                                        :phase ""}}
                                                                                                                                           :upgradeSettings {:blueGreenSettings {:nodePoolSoakDuration ""
                                                                                                                                                                                 :standardRolloutPolicy {:batchNodeCount 0
                                                                                                                                                                                                         :batchPercentage ""
                                                                                                                                                                                                         :batchSoakDuration ""}}
                                                                                                                                                             :maxSurge 0
                                                                                                                                                             :maxUnavailable 0
                                                                                                                                                             :strategy ""}
                                                                                                                                           :version ""}
                                                                                                                                :parent ""
                                                                                                                                :projectId ""
                                                                                                                                :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 3993

{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  nodePool: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    conditions: [
      {
        canonicalCode: '',
        code: '',
        message: ''
      }
    ],
    config: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {
            gpuSharingStrategy: '',
            maxSharedClientsPerGpu: ''
          },
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {
        threadsPerCore: ''
      },
      bootDiskKmsKey: '',
      confidentialNodes: {
        enabled: false
      },
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {
        localSsdCount: 0
      },
      ephemeralStorageLocalSsdConfig: {
        localSsdCount: 0
      },
      fastSocket: {
        enabled: false
      },
      gcfsConfig: {
        enabled: false
      },
      gvnic: {
        enabled: false
      },
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {
        cgroupMode: '',
        sysctls: {}
      },
      localNvmeSsdBlockConfig: {
        localSsdCount: 0
      },
      localSsdCount: 0,
      loggingConfig: {
        variantConfig: {
          variant: ''
        }
      },
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {
        consumeReservationType: '',
        key: '',
        values: []
      },
      resourceLabels: {},
      sandboxConfig: {
        sandboxType: '',
        type: ''
      },
      serviceAccount: '',
      shieldedInstanceConfig: {
        enableIntegrityMonitoring: false,
        enableSecureBoot: false
      },
      spot: false,
      tags: [],
      taints: [
        {
          effect: '',
          key: '',
          value: ''
        }
      ],
      windowsNodeConfig: {
        osVersion: ''
      },
      workloadMetadataConfig: {
        mode: '',
        nodeMetadata: ''
      }
    },
    etag: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    locations: [],
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {
        autoUpgradeStartTime: '',
        description: ''
      }
    },
    maxPodsConstraint: {
      maxPodsPerNode: ''
    },
    name: '',
    networkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {
        externalIpEgressBandwidthTier: '',
        totalEgressBandwidthTier: ''
      },
      podCidrOverprovisionConfig: {
        disable: false
      },
      podIpv4CidrBlock: '',
      podRange: ''
    },
    placementPolicy: {
      type: ''
    },
    podIpv4CidrSize: 0,
    selfLink: '',
    status: '',
    statusMessage: '',
    updateInfo: {
      blueGreenInfo: {
        blueInstanceGroupUrls: [],
        bluePoolDeletionStartTime: '',
        greenInstanceGroupUrls: [],
        greenPoolVersion: '',
        phase: ''
      }
    },
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {
          batchNodeCount: 0,
          batchPercentage: '',
          batchSoakDuration: ''
        }
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    version: ''
  },
  parent: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    nodePool: {
      autoscaling: {
        autoprovisioned: false,
        enabled: false,
        locationPolicy: '',
        maxNodeCount: 0,
        minNodeCount: 0,
        totalMaxNodeCount: 0,
        totalMinNodeCount: 0
      },
      conditions: [{canonicalCode: '', code: '', message: ''}],
      config: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {enabled: false},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      etag: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      locations: [],
      management: {
        autoRepair: false,
        autoUpgrade: false,
        upgradeOptions: {autoUpgradeStartTime: '', description: ''}
      },
      maxPodsConstraint: {maxPodsPerNode: ''},
      name: '',
      networkConfig: {
        createPodRange: false,
        enablePrivateNodes: false,
        networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
        podCidrOverprovisionConfig: {disable: false},
        podIpv4CidrBlock: '',
        podRange: ''
      },
      placementPolicy: {type: ''},
      podIpv4CidrSize: 0,
      selfLink: '',
      status: '',
      statusMessage: '',
      updateInfo: {
        blueGreenInfo: {
          blueInstanceGroupUrls: [],
          bluePoolDeletionStartTime: '',
          greenInstanceGroupUrls: [],
          greenPoolVersion: '',
          phase: ''
        }
      },
      upgradeSettings: {
        blueGreenSettings: {
          nodePoolSoakDuration: '',
          standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
        },
        maxSurge: 0,
        maxUnavailable: 0,
        strategy: ''
      },
      version: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","nodePool":{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"conditions":[{"canonicalCode":"","code":"","message":""}],"config":{"accelerators":[{"acceleratorCount":"","acceleratorType":"","gpuPartitionSize":"","gpuSharingConfig":{"gpuSharingStrategy":"","maxSharedClientsPerGpu":""},"maxTimeSharedClientsPerGpu":""}],"advancedMachineFeatures":{"threadsPerCore":""},"bootDiskKmsKey":"","confidentialNodes":{"enabled":false},"diskSizeGb":0,"diskType":"","ephemeralStorageConfig":{"localSsdCount":0},"ephemeralStorageLocalSsdConfig":{"localSsdCount":0},"fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"localNvmeSsdBlockConfig":{"localSsdCount":0},"localSsdCount":0,"loggingConfig":{"variantConfig":{"variant":""}},"machineType":"","metadata":{},"minCpuPlatform":"","nodeGroup":"","oauthScopes":[],"preemptible":false,"reservationAffinity":{"consumeReservationType":"","key":"","values":[]},"resourceLabels":{},"sandboxConfig":{"sandboxType":"","type":""},"serviceAccount":"","shieldedInstanceConfig":{"enableIntegrityMonitoring":false,"enableSecureBoot":false},"spot":false,"tags":[],"taints":[{"effect":"","key":"","value":""}],"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""}},"etag":"","initialNodeCount":0,"instanceGroupUrls":[],"locations":[],"management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"maxPodsConstraint":{"maxPodsPerNode":""},"name":"","networkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{"disable":false},"podIpv4CidrBlock":"","podRange":""},"placementPolicy":{"type":""},"podIpv4CidrSize":0,"selfLink":"","status":"","statusMessage":"","updateInfo":{"blueGreenInfo":{"blueInstanceGroupUrls":[],"bluePoolDeletionStartTime":"","greenInstanceGroupUrls":[],"greenPoolVersion":"","phase":""}},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""},"version":""},"parent":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "nodePool": {\n    "autoscaling": {\n      "autoprovisioned": false,\n      "enabled": false,\n      "locationPolicy": "",\n      "maxNodeCount": 0,\n      "minNodeCount": 0,\n      "totalMaxNodeCount": 0,\n      "totalMinNodeCount": 0\n    },\n    "conditions": [\n      {\n        "canonicalCode": "",\n        "code": "",\n        "message": ""\n      }\n    ],\n    "config": {\n      "accelerators": [\n        {\n          "acceleratorCount": "",\n          "acceleratorType": "",\n          "gpuPartitionSize": "",\n          "gpuSharingConfig": {\n            "gpuSharingStrategy": "",\n            "maxSharedClientsPerGpu": ""\n          },\n          "maxTimeSharedClientsPerGpu": ""\n        }\n      ],\n      "advancedMachineFeatures": {\n        "threadsPerCore": ""\n      },\n      "bootDiskKmsKey": "",\n      "confidentialNodes": {\n        "enabled": false\n      },\n      "diskSizeGb": 0,\n      "diskType": "",\n      "ephemeralStorageConfig": {\n        "localSsdCount": 0\n      },\n      "ephemeralStorageLocalSsdConfig": {\n        "localSsdCount": 0\n      },\n      "fastSocket": {\n        "enabled": false\n      },\n      "gcfsConfig": {\n        "enabled": false\n      },\n      "gvnic": {\n        "enabled": false\n      },\n      "imageType": "",\n      "kubeletConfig": {\n        "cpuCfsQuota": false,\n        "cpuCfsQuotaPeriod": "",\n        "cpuManagerPolicy": "",\n        "podPidsLimit": ""\n      },\n      "labels": {},\n      "linuxNodeConfig": {\n        "cgroupMode": "",\n        "sysctls": {}\n      },\n      "localNvmeSsdBlockConfig": {\n        "localSsdCount": 0\n      },\n      "localSsdCount": 0,\n      "loggingConfig": {\n        "variantConfig": {\n          "variant": ""\n        }\n      },\n      "machineType": "",\n      "metadata": {},\n      "minCpuPlatform": "",\n      "nodeGroup": "",\n      "oauthScopes": [],\n      "preemptible": false,\n      "reservationAffinity": {\n        "consumeReservationType": "",\n        "key": "",\n        "values": []\n      },\n      "resourceLabels": {},\n      "sandboxConfig": {\n        "sandboxType": "",\n        "type": ""\n      },\n      "serviceAccount": "",\n      "shieldedInstanceConfig": {\n        "enableIntegrityMonitoring": false,\n        "enableSecureBoot": false\n      },\n      "spot": false,\n      "tags": [],\n      "taints": [\n        {\n          "effect": "",\n          "key": "",\n          "value": ""\n        }\n      ],\n      "windowsNodeConfig": {\n        "osVersion": ""\n      },\n      "workloadMetadataConfig": {\n        "mode": "",\n        "nodeMetadata": ""\n      }\n    },\n    "etag": "",\n    "initialNodeCount": 0,\n    "instanceGroupUrls": [],\n    "locations": [],\n    "management": {\n      "autoRepair": false,\n      "autoUpgrade": false,\n      "upgradeOptions": {\n        "autoUpgradeStartTime": "",\n        "description": ""\n      }\n    },\n    "maxPodsConstraint": {\n      "maxPodsPerNode": ""\n    },\n    "name": "",\n    "networkConfig": {\n      "createPodRange": false,\n      "enablePrivateNodes": false,\n      "networkPerformanceConfig": {\n        "externalIpEgressBandwidthTier": "",\n        "totalEgressBandwidthTier": ""\n      },\n      "podCidrOverprovisionConfig": {\n        "disable": false\n      },\n      "podIpv4CidrBlock": "",\n      "podRange": ""\n    },\n    "placementPolicy": {\n      "type": ""\n    },\n    "podIpv4CidrSize": 0,\n    "selfLink": "",\n    "status": "",\n    "statusMessage": "",\n    "updateInfo": {\n      "blueGreenInfo": {\n        "blueInstanceGroupUrls": [],\n        "bluePoolDeletionStartTime": "",\n        "greenInstanceGroupUrls": [],\n        "greenPoolVersion": "",\n        "phase": ""\n      }\n    },\n    "upgradeSettings": {\n      "blueGreenSettings": {\n        "nodePoolSoakDuration": "",\n        "standardRolloutPolicy": {\n          "batchNodeCount": 0,\n          "batchPercentage": "",\n          "batchSoakDuration": ""\n        }\n      },\n      "maxSurge": 0,\n      "maxUnavailable": 0,\n      "strategy": ""\n    },\n    "version": ""\n  },\n  "parent": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools',
  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({
  clusterId: '',
  nodePool: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    conditions: [{canonicalCode: '', code: '', message: ''}],
    config: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {threadsPerCore: ''},
      bootDiskKmsKey: '',
      confidentialNodes: {enabled: false},
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {localSsdCount: 0},
      ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
      fastSocket: {enabled: false},
      gcfsConfig: {enabled: false},
      gvnic: {enabled: false},
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {cgroupMode: '', sysctls: {}},
      localNvmeSsdBlockConfig: {localSsdCount: 0},
      localSsdCount: 0,
      loggingConfig: {variantConfig: {variant: ''}},
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {consumeReservationType: '', key: '', values: []},
      resourceLabels: {},
      sandboxConfig: {sandboxType: '', type: ''},
      serviceAccount: '',
      shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
      spot: false,
      tags: [],
      taints: [{effect: '', key: '', value: ''}],
      windowsNodeConfig: {osVersion: ''},
      workloadMetadataConfig: {mode: '', nodeMetadata: ''}
    },
    etag: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    locations: [],
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {autoUpgradeStartTime: '', description: ''}
    },
    maxPodsConstraint: {maxPodsPerNode: ''},
    name: '',
    networkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
      podCidrOverprovisionConfig: {disable: false},
      podIpv4CidrBlock: '',
      podRange: ''
    },
    placementPolicy: {type: ''},
    podIpv4CidrSize: 0,
    selfLink: '',
    status: '',
    statusMessage: '',
    updateInfo: {
      blueGreenInfo: {
        blueInstanceGroupUrls: [],
        bluePoolDeletionStartTime: '',
        greenInstanceGroupUrls: [],
        greenPoolVersion: '',
        phase: ''
      }
    },
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    version: ''
  },
  parent: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    nodePool: {
      autoscaling: {
        autoprovisioned: false,
        enabled: false,
        locationPolicy: '',
        maxNodeCount: 0,
        minNodeCount: 0,
        totalMaxNodeCount: 0,
        totalMinNodeCount: 0
      },
      conditions: [{canonicalCode: '', code: '', message: ''}],
      config: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {enabled: false},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      etag: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      locations: [],
      management: {
        autoRepair: false,
        autoUpgrade: false,
        upgradeOptions: {autoUpgradeStartTime: '', description: ''}
      },
      maxPodsConstraint: {maxPodsPerNode: ''},
      name: '',
      networkConfig: {
        createPodRange: false,
        enablePrivateNodes: false,
        networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
        podCidrOverprovisionConfig: {disable: false},
        podIpv4CidrBlock: '',
        podRange: ''
      },
      placementPolicy: {type: ''},
      podIpv4CidrSize: 0,
      selfLink: '',
      status: '',
      statusMessage: '',
      updateInfo: {
        blueGreenInfo: {
          blueInstanceGroupUrls: [],
          bluePoolDeletionStartTime: '',
          greenInstanceGroupUrls: [],
          greenPoolVersion: '',
          phase: ''
        }
      },
      upgradeSettings: {
        blueGreenSettings: {
          nodePoolSoakDuration: '',
          standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
        },
        maxSurge: 0,
        maxUnavailable: 0,
        strategy: ''
      },
      version: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  nodePool: {
    autoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    conditions: [
      {
        canonicalCode: '',
        code: '',
        message: ''
      }
    ],
    config: {
      accelerators: [
        {
          acceleratorCount: '',
          acceleratorType: '',
          gpuPartitionSize: '',
          gpuSharingConfig: {
            gpuSharingStrategy: '',
            maxSharedClientsPerGpu: ''
          },
          maxTimeSharedClientsPerGpu: ''
        }
      ],
      advancedMachineFeatures: {
        threadsPerCore: ''
      },
      bootDiskKmsKey: '',
      confidentialNodes: {
        enabled: false
      },
      diskSizeGb: 0,
      diskType: '',
      ephemeralStorageConfig: {
        localSsdCount: 0
      },
      ephemeralStorageLocalSsdConfig: {
        localSsdCount: 0
      },
      fastSocket: {
        enabled: false
      },
      gcfsConfig: {
        enabled: false
      },
      gvnic: {
        enabled: false
      },
      imageType: '',
      kubeletConfig: {
        cpuCfsQuota: false,
        cpuCfsQuotaPeriod: '',
        cpuManagerPolicy: '',
        podPidsLimit: ''
      },
      labels: {},
      linuxNodeConfig: {
        cgroupMode: '',
        sysctls: {}
      },
      localNvmeSsdBlockConfig: {
        localSsdCount: 0
      },
      localSsdCount: 0,
      loggingConfig: {
        variantConfig: {
          variant: ''
        }
      },
      machineType: '',
      metadata: {},
      minCpuPlatform: '',
      nodeGroup: '',
      oauthScopes: [],
      preemptible: false,
      reservationAffinity: {
        consumeReservationType: '',
        key: '',
        values: []
      },
      resourceLabels: {},
      sandboxConfig: {
        sandboxType: '',
        type: ''
      },
      serviceAccount: '',
      shieldedInstanceConfig: {
        enableIntegrityMonitoring: false,
        enableSecureBoot: false
      },
      spot: false,
      tags: [],
      taints: [
        {
          effect: '',
          key: '',
          value: ''
        }
      ],
      windowsNodeConfig: {
        osVersion: ''
      },
      workloadMetadataConfig: {
        mode: '',
        nodeMetadata: ''
      }
    },
    etag: '',
    initialNodeCount: 0,
    instanceGroupUrls: [],
    locations: [],
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {
        autoUpgradeStartTime: '',
        description: ''
      }
    },
    maxPodsConstraint: {
      maxPodsPerNode: ''
    },
    name: '',
    networkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {
        externalIpEgressBandwidthTier: '',
        totalEgressBandwidthTier: ''
      },
      podCidrOverprovisionConfig: {
        disable: false
      },
      podIpv4CidrBlock: '',
      podRange: ''
    },
    placementPolicy: {
      type: ''
    },
    podIpv4CidrSize: 0,
    selfLink: '',
    status: '',
    statusMessage: '',
    updateInfo: {
      blueGreenInfo: {
        blueInstanceGroupUrls: [],
        bluePoolDeletionStartTime: '',
        greenInstanceGroupUrls: [],
        greenPoolVersion: '',
        phase: ''
      }
    },
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {
          batchNodeCount: 0,
          batchPercentage: '',
          batchSoakDuration: ''
        }
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    version: ''
  },
  parent: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    nodePool: {
      autoscaling: {
        autoprovisioned: false,
        enabled: false,
        locationPolicy: '',
        maxNodeCount: 0,
        minNodeCount: 0,
        totalMaxNodeCount: 0,
        totalMinNodeCount: 0
      },
      conditions: [{canonicalCode: '', code: '', message: ''}],
      config: {
        accelerators: [
          {
            acceleratorCount: '',
            acceleratorType: '',
            gpuPartitionSize: '',
            gpuSharingConfig: {gpuSharingStrategy: '', maxSharedClientsPerGpu: ''},
            maxTimeSharedClientsPerGpu: ''
          }
        ],
        advancedMachineFeatures: {threadsPerCore: ''},
        bootDiskKmsKey: '',
        confidentialNodes: {enabled: false},
        diskSizeGb: 0,
        diskType: '',
        ephemeralStorageConfig: {localSsdCount: 0},
        ephemeralStorageLocalSsdConfig: {localSsdCount: 0},
        fastSocket: {enabled: false},
        gcfsConfig: {enabled: false},
        gvnic: {enabled: false},
        imageType: '',
        kubeletConfig: {
          cpuCfsQuota: false,
          cpuCfsQuotaPeriod: '',
          cpuManagerPolicy: '',
          podPidsLimit: ''
        },
        labels: {},
        linuxNodeConfig: {cgroupMode: '', sysctls: {}},
        localNvmeSsdBlockConfig: {localSsdCount: 0},
        localSsdCount: 0,
        loggingConfig: {variantConfig: {variant: ''}},
        machineType: '',
        metadata: {},
        minCpuPlatform: '',
        nodeGroup: '',
        oauthScopes: [],
        preemptible: false,
        reservationAffinity: {consumeReservationType: '', key: '', values: []},
        resourceLabels: {},
        sandboxConfig: {sandboxType: '', type: ''},
        serviceAccount: '',
        shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
        spot: false,
        tags: [],
        taints: [{effect: '', key: '', value: ''}],
        windowsNodeConfig: {osVersion: ''},
        workloadMetadataConfig: {mode: '', nodeMetadata: ''}
      },
      etag: '',
      initialNodeCount: 0,
      instanceGroupUrls: [],
      locations: [],
      management: {
        autoRepair: false,
        autoUpgrade: false,
        upgradeOptions: {autoUpgradeStartTime: '', description: ''}
      },
      maxPodsConstraint: {maxPodsPerNode: ''},
      name: '',
      networkConfig: {
        createPodRange: false,
        enablePrivateNodes: false,
        networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
        podCidrOverprovisionConfig: {disable: false},
        podIpv4CidrBlock: '',
        podRange: ''
      },
      placementPolicy: {type: ''},
      podIpv4CidrSize: 0,
      selfLink: '',
      status: '',
      statusMessage: '',
      updateInfo: {
        blueGreenInfo: {
          blueInstanceGroupUrls: [],
          bluePoolDeletionStartTime: '',
          greenInstanceGroupUrls: [],
          greenPoolVersion: '',
          phase: ''
        }
      },
      upgradeSettings: {
        blueGreenSettings: {
          nodePoolSoakDuration: '',
          standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
        },
        maxSurge: 0,
        maxUnavailable: 0,
        strategy: ''
      },
      version: ''
    },
    parent: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","nodePool":{"autoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"conditions":[{"canonicalCode":"","code":"","message":""}],"config":{"accelerators":[{"acceleratorCount":"","acceleratorType":"","gpuPartitionSize":"","gpuSharingConfig":{"gpuSharingStrategy":"","maxSharedClientsPerGpu":""},"maxTimeSharedClientsPerGpu":""}],"advancedMachineFeatures":{"threadsPerCore":""},"bootDiskKmsKey":"","confidentialNodes":{"enabled":false},"diskSizeGb":0,"diskType":"","ephemeralStorageConfig":{"localSsdCount":0},"ephemeralStorageLocalSsdConfig":{"localSsdCount":0},"fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"localNvmeSsdBlockConfig":{"localSsdCount":0},"localSsdCount":0,"loggingConfig":{"variantConfig":{"variant":""}},"machineType":"","metadata":{},"minCpuPlatform":"","nodeGroup":"","oauthScopes":[],"preemptible":false,"reservationAffinity":{"consumeReservationType":"","key":"","values":[]},"resourceLabels":{},"sandboxConfig":{"sandboxType":"","type":""},"serviceAccount":"","shieldedInstanceConfig":{"enableIntegrityMonitoring":false,"enableSecureBoot":false},"spot":false,"tags":[],"taints":[{"effect":"","key":"","value":""}],"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""}},"etag":"","initialNodeCount":0,"instanceGroupUrls":[],"locations":[],"management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"maxPodsConstraint":{"maxPodsPerNode":""},"name":"","networkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{"disable":false},"podIpv4CidrBlock":"","podRange":""},"placementPolicy":{"type":""},"podIpv4CidrSize":0,"selfLink":"","status":"","statusMessage":"","updateInfo":{"blueGreenInfo":{"blueInstanceGroupUrls":[],"bluePoolDeletionStartTime":"","greenInstanceGroupUrls":[],"greenPoolVersion":"","phase":""}},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""},"version":""},"parent":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"nodePool": @{ @"autoscaling": @{ @"autoprovisioned": @NO, @"enabled": @NO, @"locationPolicy": @"", @"maxNodeCount": @0, @"minNodeCount": @0, @"totalMaxNodeCount": @0, @"totalMinNodeCount": @0 }, @"conditions": @[ @{ @"canonicalCode": @"", @"code": @"", @"message": @"" } ], @"config": @{ @"accelerators": @[ @{ @"acceleratorCount": @"", @"acceleratorType": @"", @"gpuPartitionSize": @"", @"gpuSharingConfig": @{ @"gpuSharingStrategy": @"", @"maxSharedClientsPerGpu": @"" }, @"maxTimeSharedClientsPerGpu": @"" } ], @"advancedMachineFeatures": @{ @"threadsPerCore": @"" }, @"bootDiskKmsKey": @"", @"confidentialNodes": @{ @"enabled": @NO }, @"diskSizeGb": @0, @"diskType": @"", @"ephemeralStorageConfig": @{ @"localSsdCount": @0 }, @"ephemeralStorageLocalSsdConfig": @{ @"localSsdCount": @0 }, @"fastSocket": @{ @"enabled": @NO }, @"gcfsConfig": @{ @"enabled": @NO }, @"gvnic": @{ @"enabled": @NO }, @"imageType": @"", @"kubeletConfig": @{ @"cpuCfsQuota": @NO, @"cpuCfsQuotaPeriod": @"", @"cpuManagerPolicy": @"", @"podPidsLimit": @"" }, @"labels": @{  }, @"linuxNodeConfig": @{ @"cgroupMode": @"", @"sysctls": @{  } }, @"localNvmeSsdBlockConfig": @{ @"localSsdCount": @0 }, @"localSsdCount": @0, @"loggingConfig": @{ @"variantConfig": @{ @"variant": @"" } }, @"machineType": @"", @"metadata": @{  }, @"minCpuPlatform": @"", @"nodeGroup": @"", @"oauthScopes": @[  ], @"preemptible": @NO, @"reservationAffinity": @{ @"consumeReservationType": @"", @"key": @"", @"values": @[  ] }, @"resourceLabels": @{  }, @"sandboxConfig": @{ @"sandboxType": @"", @"type": @"" }, @"serviceAccount": @"", @"shieldedInstanceConfig": @{ @"enableIntegrityMonitoring": @NO, @"enableSecureBoot": @NO }, @"spot": @NO, @"tags": @[  ], @"taints": @[ @{ @"effect": @"", @"key": @"", @"value": @"" } ], @"windowsNodeConfig": @{ @"osVersion": @"" }, @"workloadMetadataConfig": @{ @"mode": @"", @"nodeMetadata": @"" } }, @"etag": @"", @"initialNodeCount": @0, @"instanceGroupUrls": @[  ], @"locations": @[  ], @"management": @{ @"autoRepair": @NO, @"autoUpgrade": @NO, @"upgradeOptions": @{ @"autoUpgradeStartTime": @"", @"description": @"" } }, @"maxPodsConstraint": @{ @"maxPodsPerNode": @"" }, @"name": @"", @"networkConfig": @{ @"createPodRange": @NO, @"enablePrivateNodes": @NO, @"networkPerformanceConfig": @{ @"externalIpEgressBandwidthTier": @"", @"totalEgressBandwidthTier": @"" }, @"podCidrOverprovisionConfig": @{ @"disable": @NO }, @"podIpv4CidrBlock": @"", @"podRange": @"" }, @"placementPolicy": @{ @"type": @"" }, @"podIpv4CidrSize": @0, @"selfLink": @"", @"status": @"", @"statusMessage": @"", @"updateInfo": @{ @"blueGreenInfo": @{ @"blueInstanceGroupUrls": @[  ], @"bluePoolDeletionStartTime": @"", @"greenInstanceGroupUrls": @[  ], @"greenPoolVersion": @"", @"phase": @"" } }, @"upgradeSettings": @{ @"blueGreenSettings": @{ @"nodePoolSoakDuration": @"", @"standardRolloutPolicy": @{ @"batchNodeCount": @0, @"batchPercentage": @"", @"batchSoakDuration": @"" } }, @"maxSurge": @0, @"maxUnavailable": @0, @"strategy": @"" }, @"version": @"" },
                              @"parent": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools",
  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([
    'clusterId' => '',
    'nodePool' => [
        'autoscaling' => [
                'autoprovisioned' => null,
                'enabled' => null,
                'locationPolicy' => '',
                'maxNodeCount' => 0,
                'minNodeCount' => 0,
                'totalMaxNodeCount' => 0,
                'totalMinNodeCount' => 0
        ],
        'conditions' => [
                [
                                'canonicalCode' => '',
                                'code' => '',
                                'message' => ''
                ]
        ],
        'config' => [
                'accelerators' => [
                                [
                                                                'acceleratorCount' => '',
                                                                'acceleratorType' => '',
                                                                'gpuPartitionSize' => '',
                                                                'gpuSharingConfig' => [
                                                                                                                                'gpuSharingStrategy' => '',
                                                                                                                                'maxSharedClientsPerGpu' => ''
                                                                ],
                                                                'maxTimeSharedClientsPerGpu' => ''
                                ]
                ],
                'advancedMachineFeatures' => [
                                'threadsPerCore' => ''
                ],
                'bootDiskKmsKey' => '',
                'confidentialNodes' => [
                                'enabled' => null
                ],
                'diskSizeGb' => 0,
                'diskType' => '',
                'ephemeralStorageConfig' => [
                                'localSsdCount' => 0
                ],
                'ephemeralStorageLocalSsdConfig' => [
                                'localSsdCount' => 0
                ],
                'fastSocket' => [
                                'enabled' => null
                ],
                'gcfsConfig' => [
                                'enabled' => null
                ],
                'gvnic' => [
                                'enabled' => null
                ],
                'imageType' => '',
                'kubeletConfig' => [
                                'cpuCfsQuota' => null,
                                'cpuCfsQuotaPeriod' => '',
                                'cpuManagerPolicy' => '',
                                'podPidsLimit' => ''
                ],
                'labels' => [
                                
                ],
                'linuxNodeConfig' => [
                                'cgroupMode' => '',
                                'sysctls' => [
                                                                
                                ]
                ],
                'localNvmeSsdBlockConfig' => [
                                'localSsdCount' => 0
                ],
                'localSsdCount' => 0,
                'loggingConfig' => [
                                'variantConfig' => [
                                                                'variant' => ''
                                ]
                ],
                'machineType' => '',
                'metadata' => [
                                
                ],
                'minCpuPlatform' => '',
                'nodeGroup' => '',
                'oauthScopes' => [
                                
                ],
                'preemptible' => null,
                'reservationAffinity' => [
                                'consumeReservationType' => '',
                                'key' => '',
                                'values' => [
                                                                
                                ]
                ],
                'resourceLabels' => [
                                
                ],
                'sandboxConfig' => [
                                'sandboxType' => '',
                                'type' => ''
                ],
                'serviceAccount' => '',
                'shieldedInstanceConfig' => [
                                'enableIntegrityMonitoring' => null,
                                'enableSecureBoot' => null
                ],
                'spot' => null,
                'tags' => [
                                
                ],
                'taints' => [
                                [
                                                                'effect' => '',
                                                                'key' => '',
                                                                'value' => ''
                                ]
                ],
                'windowsNodeConfig' => [
                                'osVersion' => ''
                ],
                'workloadMetadataConfig' => [
                                'mode' => '',
                                'nodeMetadata' => ''
                ]
        ],
        'etag' => '',
        'initialNodeCount' => 0,
        'instanceGroupUrls' => [
                
        ],
        'locations' => [
                
        ],
        'management' => [
                'autoRepair' => null,
                'autoUpgrade' => null,
                'upgradeOptions' => [
                                'autoUpgradeStartTime' => '',
                                'description' => ''
                ]
        ],
        'maxPodsConstraint' => [
                'maxPodsPerNode' => ''
        ],
        'name' => '',
        'networkConfig' => [
                'createPodRange' => null,
                'enablePrivateNodes' => null,
                'networkPerformanceConfig' => [
                                'externalIpEgressBandwidthTier' => '',
                                'totalEgressBandwidthTier' => ''
                ],
                'podCidrOverprovisionConfig' => [
                                'disable' => null
                ],
                'podIpv4CidrBlock' => '',
                'podRange' => ''
        ],
        'placementPolicy' => [
                'type' => ''
        ],
        'podIpv4CidrSize' => 0,
        'selfLink' => '',
        'status' => '',
        'statusMessage' => '',
        'updateInfo' => [
                'blueGreenInfo' => [
                                'blueInstanceGroupUrls' => [
                                                                
                                ],
                                'bluePoolDeletionStartTime' => '',
                                'greenInstanceGroupUrls' => [
                                                                
                                ],
                                'greenPoolVersion' => '',
                                'phase' => ''
                ]
        ],
        'upgradeSettings' => [
                'blueGreenSettings' => [
                                'nodePoolSoakDuration' => '',
                                'standardRolloutPolicy' => [
                                                                'batchNodeCount' => 0,
                                                                'batchPercentage' => '',
                                                                'batchSoakDuration' => ''
                                ]
                ],
                'maxSurge' => 0,
                'maxUnavailable' => 0,
                'strategy' => ''
        ],
        'version' => ''
    ],
    'parent' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools', [
  'body' => '{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'nodePool' => [
    'autoscaling' => [
        'autoprovisioned' => null,
        'enabled' => null,
        'locationPolicy' => '',
        'maxNodeCount' => 0,
        'minNodeCount' => 0,
        'totalMaxNodeCount' => 0,
        'totalMinNodeCount' => 0
    ],
    'conditions' => [
        [
                'canonicalCode' => '',
                'code' => '',
                'message' => ''
        ]
    ],
    'config' => [
        'accelerators' => [
                [
                                'acceleratorCount' => '',
                                'acceleratorType' => '',
                                'gpuPartitionSize' => '',
                                'gpuSharingConfig' => [
                                                                'gpuSharingStrategy' => '',
                                                                'maxSharedClientsPerGpu' => ''
                                ],
                                'maxTimeSharedClientsPerGpu' => ''
                ]
        ],
        'advancedMachineFeatures' => [
                'threadsPerCore' => ''
        ],
        'bootDiskKmsKey' => '',
        'confidentialNodes' => [
                'enabled' => null
        ],
        'diskSizeGb' => 0,
        'diskType' => '',
        'ephemeralStorageConfig' => [
                'localSsdCount' => 0
        ],
        'ephemeralStorageLocalSsdConfig' => [
                'localSsdCount' => 0
        ],
        'fastSocket' => [
                'enabled' => null
        ],
        'gcfsConfig' => [
                'enabled' => null
        ],
        'gvnic' => [
                'enabled' => null
        ],
        'imageType' => '',
        'kubeletConfig' => [
                'cpuCfsQuota' => null,
                'cpuCfsQuotaPeriod' => '',
                'cpuManagerPolicy' => '',
                'podPidsLimit' => ''
        ],
        'labels' => [
                
        ],
        'linuxNodeConfig' => [
                'cgroupMode' => '',
                'sysctls' => [
                                
                ]
        ],
        'localNvmeSsdBlockConfig' => [
                'localSsdCount' => 0
        ],
        'localSsdCount' => 0,
        'loggingConfig' => [
                'variantConfig' => [
                                'variant' => ''
                ]
        ],
        'machineType' => '',
        'metadata' => [
                
        ],
        'minCpuPlatform' => '',
        'nodeGroup' => '',
        'oauthScopes' => [
                
        ],
        'preemptible' => null,
        'reservationAffinity' => [
                'consumeReservationType' => '',
                'key' => '',
                'values' => [
                                
                ]
        ],
        'resourceLabels' => [
                
        ],
        'sandboxConfig' => [
                'sandboxType' => '',
                'type' => ''
        ],
        'serviceAccount' => '',
        'shieldedInstanceConfig' => [
                'enableIntegrityMonitoring' => null,
                'enableSecureBoot' => null
        ],
        'spot' => null,
        'tags' => [
                
        ],
        'taints' => [
                [
                                'effect' => '',
                                'key' => '',
                                'value' => ''
                ]
        ],
        'windowsNodeConfig' => [
                'osVersion' => ''
        ],
        'workloadMetadataConfig' => [
                'mode' => '',
                'nodeMetadata' => ''
        ]
    ],
    'etag' => '',
    'initialNodeCount' => 0,
    'instanceGroupUrls' => [
        
    ],
    'locations' => [
        
    ],
    'management' => [
        'autoRepair' => null,
        'autoUpgrade' => null,
        'upgradeOptions' => [
                'autoUpgradeStartTime' => '',
                'description' => ''
        ]
    ],
    'maxPodsConstraint' => [
        'maxPodsPerNode' => ''
    ],
    'name' => '',
    'networkConfig' => [
        'createPodRange' => null,
        'enablePrivateNodes' => null,
        'networkPerformanceConfig' => [
                'externalIpEgressBandwidthTier' => '',
                'totalEgressBandwidthTier' => ''
        ],
        'podCidrOverprovisionConfig' => [
                'disable' => null
        ],
        'podIpv4CidrBlock' => '',
        'podRange' => ''
    ],
    'placementPolicy' => [
        'type' => ''
    ],
    'podIpv4CidrSize' => 0,
    'selfLink' => '',
    'status' => '',
    'statusMessage' => '',
    'updateInfo' => [
        'blueGreenInfo' => [
                'blueInstanceGroupUrls' => [
                                
                ],
                'bluePoolDeletionStartTime' => '',
                'greenInstanceGroupUrls' => [
                                
                ],
                'greenPoolVersion' => '',
                'phase' => ''
        ]
    ],
    'upgradeSettings' => [
        'blueGreenSettings' => [
                'nodePoolSoakDuration' => '',
                'standardRolloutPolicy' => [
                                'batchNodeCount' => 0,
                                'batchPercentage' => '',
                                'batchSoakDuration' => ''
                ]
        ],
        'maxSurge' => 0,
        'maxUnavailable' => 0,
        'strategy' => ''
    ],
    'version' => ''
  ],
  'parent' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'nodePool' => [
    'autoscaling' => [
        'autoprovisioned' => null,
        'enabled' => null,
        'locationPolicy' => '',
        'maxNodeCount' => 0,
        'minNodeCount' => 0,
        'totalMaxNodeCount' => 0,
        'totalMinNodeCount' => 0
    ],
    'conditions' => [
        [
                'canonicalCode' => '',
                'code' => '',
                'message' => ''
        ]
    ],
    'config' => [
        'accelerators' => [
                [
                                'acceleratorCount' => '',
                                'acceleratorType' => '',
                                'gpuPartitionSize' => '',
                                'gpuSharingConfig' => [
                                                                'gpuSharingStrategy' => '',
                                                                'maxSharedClientsPerGpu' => ''
                                ],
                                'maxTimeSharedClientsPerGpu' => ''
                ]
        ],
        'advancedMachineFeatures' => [
                'threadsPerCore' => ''
        ],
        'bootDiskKmsKey' => '',
        'confidentialNodes' => [
                'enabled' => null
        ],
        'diskSizeGb' => 0,
        'diskType' => '',
        'ephemeralStorageConfig' => [
                'localSsdCount' => 0
        ],
        'ephemeralStorageLocalSsdConfig' => [
                'localSsdCount' => 0
        ],
        'fastSocket' => [
                'enabled' => null
        ],
        'gcfsConfig' => [
                'enabled' => null
        ],
        'gvnic' => [
                'enabled' => null
        ],
        'imageType' => '',
        'kubeletConfig' => [
                'cpuCfsQuota' => null,
                'cpuCfsQuotaPeriod' => '',
                'cpuManagerPolicy' => '',
                'podPidsLimit' => ''
        ],
        'labels' => [
                
        ],
        'linuxNodeConfig' => [
                'cgroupMode' => '',
                'sysctls' => [
                                
                ]
        ],
        'localNvmeSsdBlockConfig' => [
                'localSsdCount' => 0
        ],
        'localSsdCount' => 0,
        'loggingConfig' => [
                'variantConfig' => [
                                'variant' => ''
                ]
        ],
        'machineType' => '',
        'metadata' => [
                
        ],
        'minCpuPlatform' => '',
        'nodeGroup' => '',
        'oauthScopes' => [
                
        ],
        'preemptible' => null,
        'reservationAffinity' => [
                'consumeReservationType' => '',
                'key' => '',
                'values' => [
                                
                ]
        ],
        'resourceLabels' => [
                
        ],
        'sandboxConfig' => [
                'sandboxType' => '',
                'type' => ''
        ],
        'serviceAccount' => '',
        'shieldedInstanceConfig' => [
                'enableIntegrityMonitoring' => null,
                'enableSecureBoot' => null
        ],
        'spot' => null,
        'tags' => [
                
        ],
        'taints' => [
                [
                                'effect' => '',
                                'key' => '',
                                'value' => ''
                ]
        ],
        'windowsNodeConfig' => [
                'osVersion' => ''
        ],
        'workloadMetadataConfig' => [
                'mode' => '',
                'nodeMetadata' => ''
        ]
    ],
    'etag' => '',
    'initialNodeCount' => 0,
    'instanceGroupUrls' => [
        
    ],
    'locations' => [
        
    ],
    'management' => [
        'autoRepair' => null,
        'autoUpgrade' => null,
        'upgradeOptions' => [
                'autoUpgradeStartTime' => '',
                'description' => ''
        ]
    ],
    'maxPodsConstraint' => [
        'maxPodsPerNode' => ''
    ],
    'name' => '',
    'networkConfig' => [
        'createPodRange' => null,
        'enablePrivateNodes' => null,
        'networkPerformanceConfig' => [
                'externalIpEgressBandwidthTier' => '',
                'totalEgressBandwidthTier' => ''
        ],
        'podCidrOverprovisionConfig' => [
                'disable' => null
        ],
        'podIpv4CidrBlock' => '',
        'podRange' => ''
    ],
    'placementPolicy' => [
        'type' => ''
    ],
    'podIpv4CidrSize' => 0,
    'selfLink' => '',
    'status' => '',
    'statusMessage' => '',
    'updateInfo' => [
        'blueGreenInfo' => [
                'blueInstanceGroupUrls' => [
                                
                ],
                'bluePoolDeletionStartTime' => '',
                'greenInstanceGroupUrls' => [
                                
                ],
                'greenPoolVersion' => '',
                'phase' => ''
        ]
    ],
    'upgradeSettings' => [
        'blueGreenSettings' => [
                'nodePoolSoakDuration' => '',
                'standardRolloutPolicy' => [
                                'batchNodeCount' => 0,
                                'batchPercentage' => '',
                                'batchSoakDuration' => ''
                ]
        ],
        'maxSurge' => 0,
        'maxUnavailable' => 0,
        'strategy' => ''
    ],
    'version' => ''
  ],
  'parent' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"

payload = {
    "clusterId": "",
    "nodePool": {
        "autoscaling": {
            "autoprovisioned": False,
            "enabled": False,
            "locationPolicy": "",
            "maxNodeCount": 0,
            "minNodeCount": 0,
            "totalMaxNodeCount": 0,
            "totalMinNodeCount": 0
        },
        "conditions": [
            {
                "canonicalCode": "",
                "code": "",
                "message": ""
            }
        ],
        "config": {
            "accelerators": [
                {
                    "acceleratorCount": "",
                    "acceleratorType": "",
                    "gpuPartitionSize": "",
                    "gpuSharingConfig": {
                        "gpuSharingStrategy": "",
                        "maxSharedClientsPerGpu": ""
                    },
                    "maxTimeSharedClientsPerGpu": ""
                }
            ],
            "advancedMachineFeatures": { "threadsPerCore": "" },
            "bootDiskKmsKey": "",
            "confidentialNodes": { "enabled": False },
            "diskSizeGb": 0,
            "diskType": "",
            "ephemeralStorageConfig": { "localSsdCount": 0 },
            "ephemeralStorageLocalSsdConfig": { "localSsdCount": 0 },
            "fastSocket": { "enabled": False },
            "gcfsConfig": { "enabled": False },
            "gvnic": { "enabled": False },
            "imageType": "",
            "kubeletConfig": {
                "cpuCfsQuota": False,
                "cpuCfsQuotaPeriod": "",
                "cpuManagerPolicy": "",
                "podPidsLimit": ""
            },
            "labels": {},
            "linuxNodeConfig": {
                "cgroupMode": "",
                "sysctls": {}
            },
            "localNvmeSsdBlockConfig": { "localSsdCount": 0 },
            "localSsdCount": 0,
            "loggingConfig": { "variantConfig": { "variant": "" } },
            "machineType": "",
            "metadata": {},
            "minCpuPlatform": "",
            "nodeGroup": "",
            "oauthScopes": [],
            "preemptible": False,
            "reservationAffinity": {
                "consumeReservationType": "",
                "key": "",
                "values": []
            },
            "resourceLabels": {},
            "sandboxConfig": {
                "sandboxType": "",
                "type": ""
            },
            "serviceAccount": "",
            "shieldedInstanceConfig": {
                "enableIntegrityMonitoring": False,
                "enableSecureBoot": False
            },
            "spot": False,
            "tags": [],
            "taints": [
                {
                    "effect": "",
                    "key": "",
                    "value": ""
                }
            ],
            "windowsNodeConfig": { "osVersion": "" },
            "workloadMetadataConfig": {
                "mode": "",
                "nodeMetadata": ""
            }
        },
        "etag": "",
        "initialNodeCount": 0,
        "instanceGroupUrls": [],
        "locations": [],
        "management": {
            "autoRepair": False,
            "autoUpgrade": False,
            "upgradeOptions": {
                "autoUpgradeStartTime": "",
                "description": ""
            }
        },
        "maxPodsConstraint": { "maxPodsPerNode": "" },
        "name": "",
        "networkConfig": {
            "createPodRange": False,
            "enablePrivateNodes": False,
            "networkPerformanceConfig": {
                "externalIpEgressBandwidthTier": "",
                "totalEgressBandwidthTier": ""
            },
            "podCidrOverprovisionConfig": { "disable": False },
            "podIpv4CidrBlock": "",
            "podRange": ""
        },
        "placementPolicy": { "type": "" },
        "podIpv4CidrSize": 0,
        "selfLink": "",
        "status": "",
        "statusMessage": "",
        "updateInfo": { "blueGreenInfo": {
                "blueInstanceGroupUrls": [],
                "bluePoolDeletionStartTime": "",
                "greenInstanceGroupUrls": [],
                "greenPoolVersion": "",
                "phase": ""
            } },
        "upgradeSettings": {
            "blueGreenSettings": {
                "nodePoolSoakDuration": "",
                "standardRolloutPolicy": {
                    "batchNodeCount": 0,
                    "batchPercentage": "",
                    "batchSoakDuration": ""
                }
            },
            "maxSurge": 0,
            "maxUnavailable": 0,
            "strategy": ""
        },
        "version": ""
    },
    "parent": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"

payload <- "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")

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  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"nodePool\": {\n    \"autoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"conditions\": [\n      {\n        \"canonicalCode\": \"\",\n        \"code\": \"\",\n        \"message\": \"\"\n      }\n    ],\n    \"config\": {\n      \"accelerators\": [\n        {\n          \"acceleratorCount\": \"\",\n          \"acceleratorType\": \"\",\n          \"gpuPartitionSize\": \"\",\n          \"gpuSharingConfig\": {\n            \"gpuSharingStrategy\": \"\",\n            \"maxSharedClientsPerGpu\": \"\"\n          },\n          \"maxTimeSharedClientsPerGpu\": \"\"\n        }\n      ],\n      \"advancedMachineFeatures\": {\n        \"threadsPerCore\": \"\"\n      },\n      \"bootDiskKmsKey\": \"\",\n      \"confidentialNodes\": {\n        \"enabled\": false\n      },\n      \"diskSizeGb\": 0,\n      \"diskType\": \"\",\n      \"ephemeralStorageConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"ephemeralStorageLocalSsdConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"fastSocket\": {\n        \"enabled\": false\n      },\n      \"gcfsConfig\": {\n        \"enabled\": false\n      },\n      \"gvnic\": {\n        \"enabled\": false\n      },\n      \"imageType\": \"\",\n      \"kubeletConfig\": {\n        \"cpuCfsQuota\": false,\n        \"cpuCfsQuotaPeriod\": \"\",\n        \"cpuManagerPolicy\": \"\",\n        \"podPidsLimit\": \"\"\n      },\n      \"labels\": {},\n      \"linuxNodeConfig\": {\n        \"cgroupMode\": \"\",\n        \"sysctls\": {}\n      },\n      \"localNvmeSsdBlockConfig\": {\n        \"localSsdCount\": 0\n      },\n      \"localSsdCount\": 0,\n      \"loggingConfig\": {\n        \"variantConfig\": {\n          \"variant\": \"\"\n        }\n      },\n      \"machineType\": \"\",\n      \"metadata\": {},\n      \"minCpuPlatform\": \"\",\n      \"nodeGroup\": \"\",\n      \"oauthScopes\": [],\n      \"preemptible\": false,\n      \"reservationAffinity\": {\n        \"consumeReservationType\": \"\",\n        \"key\": \"\",\n        \"values\": []\n      },\n      \"resourceLabels\": {},\n      \"sandboxConfig\": {\n        \"sandboxType\": \"\",\n        \"type\": \"\"\n      },\n      \"serviceAccount\": \"\",\n      \"shieldedInstanceConfig\": {\n        \"enableIntegrityMonitoring\": false,\n        \"enableSecureBoot\": false\n      },\n      \"spot\": false,\n      \"tags\": [],\n      \"taints\": [\n        {\n          \"effect\": \"\",\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      ],\n      \"windowsNodeConfig\": {\n        \"osVersion\": \"\"\n      },\n      \"workloadMetadataConfig\": {\n        \"mode\": \"\",\n        \"nodeMetadata\": \"\"\n      }\n    },\n    \"etag\": \"\",\n    \"initialNodeCount\": 0,\n    \"instanceGroupUrls\": [],\n    \"locations\": [],\n    \"management\": {\n      \"autoRepair\": false,\n      \"autoUpgrade\": false,\n      \"upgradeOptions\": {\n        \"autoUpgradeStartTime\": \"\",\n        \"description\": \"\"\n      }\n    },\n    \"maxPodsConstraint\": {\n      \"maxPodsPerNode\": \"\"\n    },\n    \"name\": \"\",\n    \"networkConfig\": {\n      \"createPodRange\": false,\n      \"enablePrivateNodes\": false,\n      \"networkPerformanceConfig\": {\n        \"externalIpEgressBandwidthTier\": \"\",\n        \"totalEgressBandwidthTier\": \"\"\n      },\n      \"podCidrOverprovisionConfig\": {\n        \"disable\": false\n      },\n      \"podIpv4CidrBlock\": \"\",\n      \"podRange\": \"\"\n    },\n    \"placementPolicy\": {\n      \"type\": \"\"\n    },\n    \"podIpv4CidrSize\": 0,\n    \"selfLink\": \"\",\n    \"status\": \"\",\n    \"statusMessage\": \"\",\n    \"updateInfo\": {\n      \"blueGreenInfo\": {\n        \"blueInstanceGroupUrls\": [],\n        \"bluePoolDeletionStartTime\": \"\",\n        \"greenInstanceGroupUrls\": [],\n        \"greenPoolVersion\": \"\",\n        \"phase\": \"\"\n      }\n    },\n    \"upgradeSettings\": {\n      \"blueGreenSettings\": {\n        \"nodePoolSoakDuration\": \"\",\n        \"standardRolloutPolicy\": {\n          \"batchNodeCount\": 0,\n          \"batchPercentage\": \"\",\n          \"batchSoakDuration\": \"\"\n        }\n      },\n      \"maxSurge\": 0,\n      \"maxUnavailable\": 0,\n      \"strategy\": \"\"\n    },\n    \"version\": \"\"\n  },\n  \"parent\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools";

    let payload = json!({
        "clusterId": "",
        "nodePool": json!({
            "autoscaling": json!({
                "autoprovisioned": false,
                "enabled": false,
                "locationPolicy": "",
                "maxNodeCount": 0,
                "minNodeCount": 0,
                "totalMaxNodeCount": 0,
                "totalMinNodeCount": 0
            }),
            "conditions": (
                json!({
                    "canonicalCode": "",
                    "code": "",
                    "message": ""
                })
            ),
            "config": json!({
                "accelerators": (
                    json!({
                        "acceleratorCount": "",
                        "acceleratorType": "",
                        "gpuPartitionSize": "",
                        "gpuSharingConfig": json!({
                            "gpuSharingStrategy": "",
                            "maxSharedClientsPerGpu": ""
                        }),
                        "maxTimeSharedClientsPerGpu": ""
                    })
                ),
                "advancedMachineFeatures": json!({"threadsPerCore": ""}),
                "bootDiskKmsKey": "",
                "confidentialNodes": json!({"enabled": false}),
                "diskSizeGb": 0,
                "diskType": "",
                "ephemeralStorageConfig": json!({"localSsdCount": 0}),
                "ephemeralStorageLocalSsdConfig": json!({"localSsdCount": 0}),
                "fastSocket": json!({"enabled": false}),
                "gcfsConfig": json!({"enabled": false}),
                "gvnic": json!({"enabled": false}),
                "imageType": "",
                "kubeletConfig": json!({
                    "cpuCfsQuota": false,
                    "cpuCfsQuotaPeriod": "",
                    "cpuManagerPolicy": "",
                    "podPidsLimit": ""
                }),
                "labels": json!({}),
                "linuxNodeConfig": json!({
                    "cgroupMode": "",
                    "sysctls": json!({})
                }),
                "localNvmeSsdBlockConfig": json!({"localSsdCount": 0}),
                "localSsdCount": 0,
                "loggingConfig": json!({"variantConfig": json!({"variant": ""})}),
                "machineType": "",
                "metadata": json!({}),
                "minCpuPlatform": "",
                "nodeGroup": "",
                "oauthScopes": (),
                "preemptible": false,
                "reservationAffinity": json!({
                    "consumeReservationType": "",
                    "key": "",
                    "values": ()
                }),
                "resourceLabels": json!({}),
                "sandboxConfig": json!({
                    "sandboxType": "",
                    "type": ""
                }),
                "serviceAccount": "",
                "shieldedInstanceConfig": json!({
                    "enableIntegrityMonitoring": false,
                    "enableSecureBoot": false
                }),
                "spot": false,
                "tags": (),
                "taints": (
                    json!({
                        "effect": "",
                        "key": "",
                        "value": ""
                    })
                ),
                "windowsNodeConfig": json!({"osVersion": ""}),
                "workloadMetadataConfig": json!({
                    "mode": "",
                    "nodeMetadata": ""
                })
            }),
            "etag": "",
            "initialNodeCount": 0,
            "instanceGroupUrls": (),
            "locations": (),
            "management": json!({
                "autoRepair": false,
                "autoUpgrade": false,
                "upgradeOptions": json!({
                    "autoUpgradeStartTime": "",
                    "description": ""
                })
            }),
            "maxPodsConstraint": json!({"maxPodsPerNode": ""}),
            "name": "",
            "networkConfig": json!({
                "createPodRange": false,
                "enablePrivateNodes": false,
                "networkPerformanceConfig": json!({
                    "externalIpEgressBandwidthTier": "",
                    "totalEgressBandwidthTier": ""
                }),
                "podCidrOverprovisionConfig": json!({"disable": false}),
                "podIpv4CidrBlock": "",
                "podRange": ""
            }),
            "placementPolicy": json!({"type": ""}),
            "podIpv4CidrSize": 0,
            "selfLink": "",
            "status": "",
            "statusMessage": "",
            "updateInfo": json!({"blueGreenInfo": json!({
                    "blueInstanceGroupUrls": (),
                    "bluePoolDeletionStartTime": "",
                    "greenInstanceGroupUrls": (),
                    "greenPoolVersion": "",
                    "phase": ""
                })}),
            "upgradeSettings": json!({
                "blueGreenSettings": json!({
                    "nodePoolSoakDuration": "",
                    "standardRolloutPolicy": json!({
                        "batchNodeCount": 0,
                        "batchPercentage": "",
                        "batchSoakDuration": ""
                    })
                }),
                "maxSurge": 0,
                "maxUnavailable": 0,
                "strategy": ""
            }),
            "version": ""
        }),
        "parent": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "nodePool": {
    "autoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "conditions": [
      {
        "canonicalCode": "",
        "code": "",
        "message": ""
      }
    ],
    "config": {
      "accelerators": [
        {
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": {
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          },
          "maxTimeSharedClientsPerGpu": ""
        }
      ],
      "advancedMachineFeatures": {
        "threadsPerCore": ""
      },
      "bootDiskKmsKey": "",
      "confidentialNodes": {
        "enabled": false
      },
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": {
        "localSsdCount": 0
      },
      "ephemeralStorageLocalSsdConfig": {
        "localSsdCount": 0
      },
      "fastSocket": {
        "enabled": false
      },
      "gcfsConfig": {
        "enabled": false
      },
      "gvnic": {
        "enabled": false
      },
      "imageType": "",
      "kubeletConfig": {
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      },
      "labels": {},
      "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
      },
      "localNvmeSsdBlockConfig": {
        "localSsdCount": 0
      },
      "localSsdCount": 0,
      "loggingConfig": {
        "variantConfig": {
          "variant": ""
        }
      },
      "machineType": "",
      "metadata": {},
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": {
        "consumeReservationType": "",
        "key": "",
        "values": []
      },
      "resourceLabels": {},
      "sandboxConfig": {
        "sandboxType": "",
        "type": ""
      },
      "serviceAccount": "",
      "shieldedInstanceConfig": {
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      },
      "spot": false,
      "tags": [],
      "taints": [
        {
          "effect": "",
          "key": "",
          "value": ""
        }
      ],
      "windowsNodeConfig": {
        "osVersion": ""
      },
      "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
      }
    },
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": {
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": {
        "autoUpgradeStartTime": "",
        "description": ""
      }
    },
    "maxPodsConstraint": {
      "maxPodsPerNode": ""
    },
    "name": "",
    "networkConfig": {
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": {
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      },
      "podCidrOverprovisionConfig": {
        "disable": false
      },
      "podIpv4CidrBlock": "",
      "podRange": ""
    },
    "placementPolicy": {
      "type": ""
    },
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": {
      "blueGreenInfo": {
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      }
    },
    "upgradeSettings": {
      "blueGreenSettings": {
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": {
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        }
      },
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    },
    "version": ""
  },
  "parent": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "nodePool": {\n    "autoscaling": {\n      "autoprovisioned": false,\n      "enabled": false,\n      "locationPolicy": "",\n      "maxNodeCount": 0,\n      "minNodeCount": 0,\n      "totalMaxNodeCount": 0,\n      "totalMinNodeCount": 0\n    },\n    "conditions": [\n      {\n        "canonicalCode": "",\n        "code": "",\n        "message": ""\n      }\n    ],\n    "config": {\n      "accelerators": [\n        {\n          "acceleratorCount": "",\n          "acceleratorType": "",\n          "gpuPartitionSize": "",\n          "gpuSharingConfig": {\n            "gpuSharingStrategy": "",\n            "maxSharedClientsPerGpu": ""\n          },\n          "maxTimeSharedClientsPerGpu": ""\n        }\n      ],\n      "advancedMachineFeatures": {\n        "threadsPerCore": ""\n      },\n      "bootDiskKmsKey": "",\n      "confidentialNodes": {\n        "enabled": false\n      },\n      "diskSizeGb": 0,\n      "diskType": "",\n      "ephemeralStorageConfig": {\n        "localSsdCount": 0\n      },\n      "ephemeralStorageLocalSsdConfig": {\n        "localSsdCount": 0\n      },\n      "fastSocket": {\n        "enabled": false\n      },\n      "gcfsConfig": {\n        "enabled": false\n      },\n      "gvnic": {\n        "enabled": false\n      },\n      "imageType": "",\n      "kubeletConfig": {\n        "cpuCfsQuota": false,\n        "cpuCfsQuotaPeriod": "",\n        "cpuManagerPolicy": "",\n        "podPidsLimit": ""\n      },\n      "labels": {},\n      "linuxNodeConfig": {\n        "cgroupMode": "",\n        "sysctls": {}\n      },\n      "localNvmeSsdBlockConfig": {\n        "localSsdCount": 0\n      },\n      "localSsdCount": 0,\n      "loggingConfig": {\n        "variantConfig": {\n          "variant": ""\n        }\n      },\n      "machineType": "",\n      "metadata": {},\n      "minCpuPlatform": "",\n      "nodeGroup": "",\n      "oauthScopes": [],\n      "preemptible": false,\n      "reservationAffinity": {\n        "consumeReservationType": "",\n        "key": "",\n        "values": []\n      },\n      "resourceLabels": {},\n      "sandboxConfig": {\n        "sandboxType": "",\n        "type": ""\n      },\n      "serviceAccount": "",\n      "shieldedInstanceConfig": {\n        "enableIntegrityMonitoring": false,\n        "enableSecureBoot": false\n      },\n      "spot": false,\n      "tags": [],\n      "taints": [\n        {\n          "effect": "",\n          "key": "",\n          "value": ""\n        }\n      ],\n      "windowsNodeConfig": {\n        "osVersion": ""\n      },\n      "workloadMetadataConfig": {\n        "mode": "",\n        "nodeMetadata": ""\n      }\n    },\n    "etag": "",\n    "initialNodeCount": 0,\n    "instanceGroupUrls": [],\n    "locations": [],\n    "management": {\n      "autoRepair": false,\n      "autoUpgrade": false,\n      "upgradeOptions": {\n        "autoUpgradeStartTime": "",\n        "description": ""\n      }\n    },\n    "maxPodsConstraint": {\n      "maxPodsPerNode": ""\n    },\n    "name": "",\n    "networkConfig": {\n      "createPodRange": false,\n      "enablePrivateNodes": false,\n      "networkPerformanceConfig": {\n        "externalIpEgressBandwidthTier": "",\n        "totalEgressBandwidthTier": ""\n      },\n      "podCidrOverprovisionConfig": {\n        "disable": false\n      },\n      "podIpv4CidrBlock": "",\n      "podRange": ""\n    },\n    "placementPolicy": {\n      "type": ""\n    },\n    "podIpv4CidrSize": 0,\n    "selfLink": "",\n    "status": "",\n    "statusMessage": "",\n    "updateInfo": {\n      "blueGreenInfo": {\n        "blueInstanceGroupUrls": [],\n        "bluePoolDeletionStartTime": "",\n        "greenInstanceGroupUrls": [],\n        "greenPoolVersion": "",\n        "phase": ""\n      }\n    },\n    "upgradeSettings": {\n      "blueGreenSettings": {\n        "nodePoolSoakDuration": "",\n        "standardRolloutPolicy": {\n          "batchNodeCount": 0,\n          "batchPercentage": "",\n          "batchSoakDuration": ""\n        }\n      },\n      "maxSurge": 0,\n      "maxUnavailable": 0,\n      "strategy": ""\n    },\n    "version": ""\n  },\n  "parent": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "nodePool": [
    "autoscaling": [
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    ],
    "conditions": [
      [
        "canonicalCode": "",
        "code": "",
        "message": ""
      ]
    ],
    "config": [
      "accelerators": [
        [
          "acceleratorCount": "",
          "acceleratorType": "",
          "gpuPartitionSize": "",
          "gpuSharingConfig": [
            "gpuSharingStrategy": "",
            "maxSharedClientsPerGpu": ""
          ],
          "maxTimeSharedClientsPerGpu": ""
        ]
      ],
      "advancedMachineFeatures": ["threadsPerCore": ""],
      "bootDiskKmsKey": "",
      "confidentialNodes": ["enabled": false],
      "diskSizeGb": 0,
      "diskType": "",
      "ephemeralStorageConfig": ["localSsdCount": 0],
      "ephemeralStorageLocalSsdConfig": ["localSsdCount": 0],
      "fastSocket": ["enabled": false],
      "gcfsConfig": ["enabled": false],
      "gvnic": ["enabled": false],
      "imageType": "",
      "kubeletConfig": [
        "cpuCfsQuota": false,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
      ],
      "labels": [],
      "linuxNodeConfig": [
        "cgroupMode": "",
        "sysctls": []
      ],
      "localNvmeSsdBlockConfig": ["localSsdCount": 0],
      "localSsdCount": 0,
      "loggingConfig": ["variantConfig": ["variant": ""]],
      "machineType": "",
      "metadata": [],
      "minCpuPlatform": "",
      "nodeGroup": "",
      "oauthScopes": [],
      "preemptible": false,
      "reservationAffinity": [
        "consumeReservationType": "",
        "key": "",
        "values": []
      ],
      "resourceLabels": [],
      "sandboxConfig": [
        "sandboxType": "",
        "type": ""
      ],
      "serviceAccount": "",
      "shieldedInstanceConfig": [
        "enableIntegrityMonitoring": false,
        "enableSecureBoot": false
      ],
      "spot": false,
      "tags": [],
      "taints": [
        [
          "effect": "",
          "key": "",
          "value": ""
        ]
      ],
      "windowsNodeConfig": ["osVersion": ""],
      "workloadMetadataConfig": [
        "mode": "",
        "nodeMetadata": ""
      ]
    ],
    "etag": "",
    "initialNodeCount": 0,
    "instanceGroupUrls": [],
    "locations": [],
    "management": [
      "autoRepair": false,
      "autoUpgrade": false,
      "upgradeOptions": [
        "autoUpgradeStartTime": "",
        "description": ""
      ]
    ],
    "maxPodsConstraint": ["maxPodsPerNode": ""],
    "name": "",
    "networkConfig": [
      "createPodRange": false,
      "enablePrivateNodes": false,
      "networkPerformanceConfig": [
        "externalIpEgressBandwidthTier": "",
        "totalEgressBandwidthTier": ""
      ],
      "podCidrOverprovisionConfig": ["disable": false],
      "podIpv4CidrBlock": "",
      "podRange": ""
    ],
    "placementPolicy": ["type": ""],
    "podIpv4CidrSize": 0,
    "selfLink": "",
    "status": "",
    "statusMessage": "",
    "updateInfo": ["blueGreenInfo": [
        "blueInstanceGroupUrls": [],
        "bluePoolDeletionStartTime": "",
        "greenInstanceGroupUrls": [],
        "greenPoolVersion": "",
        "phase": ""
      ]],
    "upgradeSettings": [
      "blueGreenSettings": [
        "nodePoolSoakDuration": "",
        "standardRolloutPolicy": [
          "batchNodeCount": 0,
          "batchPercentage": "",
          "batchSoakDuration": ""
        ]
      ],
      "maxSurge": 0,
      "maxUnavailable": 0,
      "strategy": ""
    ],
    "version": ""
  ],
  "parent": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")! 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 container.projects.zones.clusters.nodePools.delete
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId
QUERY PARAMS

projectId
zone
clusterId
nodePoolId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "DELETE");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/delete "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId");
var request = new RestRequest("", Method.Delete);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"

	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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("DELETE", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"))
    .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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")
  .delete(null)
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.delete("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")
  .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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'DELETE',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId',
  method: 'DELETE',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")
  .delete(null)
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'DELETE',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId',
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('DELETE', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId');

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId" in

Client.call `DELETE uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId",
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId');
$request->setMethod(HTTP_METH_DELETE);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId');
$request->setRequestMethod('DELETE');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId' -Method DELETE 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId' -Method DELETE 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("DELETE", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"

response = requests.delete(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"

response <- VERB("DELETE", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")

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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId') do |req|
end

puts response.status
puts response.body
use std::str::FromStr;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId";

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId
http DELETE {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId
wget --quiet \
  --method DELETE \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")! 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 container.projects.zones.clusters.nodePools.get
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId
QUERY PARAMS

projectId
zone
clusterId
nodePoolId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"

	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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"))
    .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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")
  .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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId',
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId');

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId",
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")

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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId";

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId
http GET {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId")! 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 container.projects.zones.clusters.nodePools.list
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools
QUERY PARAMS

projectId
zone
clusterId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"

	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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"))
    .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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")
  .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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools',
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools');

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools';
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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools",
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")

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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools";

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools
http GET {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools")! 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 container.projects.zones.clusters.nodePools.rollback
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback
QUERY PARAMS

projectId
zone
clusterId
nodePoolId
BODY json

{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback");

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback" {:content-type :json
                                                                                                                                       :form-params {:clusterId ""
                                                                                                                                                     :name ""
                                                                                                                                                     :nodePoolId ""
                                                                                                                                                     :projectId ""
                                                                                                                                                     :respectPdb false
                                                                                                                                                     :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 111

{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  respectPdb: false,
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    respectPdb: false,
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","nodePoolId":"","projectId":"","respectPdb":false,"zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "respectPdb": false,\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback',
  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({
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  respectPdb: false,
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    respectPdb: false,
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  name: '',
  nodePoolId: '',
  projectId: '',
  respectPdb: false,
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    name: '',
    nodePoolId: '',
    projectId: '',
    respectPdb: false,
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","nodePoolId":"","projectId":"","respectPdb":false,"zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"name": @"",
                              @"nodePoolId": @"",
                              @"projectId": @"",
                              @"respectPdb": @NO,
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback",
  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([
    'clusterId' => '',
    'name' => '',
    'nodePoolId' => '',
    'projectId' => '',
    'respectPdb' => null,
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback', [
  'body' => '{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'respectPdb' => null,
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'respectPdb' => null,
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback"

payload = {
    "clusterId": "",
    "name": "",
    "nodePoolId": "",
    "projectId": "",
    "respectPdb": False,
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback"

payload <- "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback")

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"respectPdb\": false,\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback";

    let payload = json!({
        "clusterId": "",
        "name": "",
        "nodePoolId": "",
        "projectId": "",
        "respectPdb": false,
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}'
echo '{
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "respectPdb": false,\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "respectPdb": false,
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId:rollback")! 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 container.projects.zones.clusters.nodePools.setManagement
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement
QUERY PARAMS

projectId
zone
clusterId
nodePoolId
BODY json

{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement");

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  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement" {:content-type :json
                                                                                                                                            :form-params {:clusterId ""
                                                                                                                                                          :management {:autoRepair false
                                                                                                                                                                       :autoUpgrade false
                                                                                                                                                                       :upgradeOptions {:autoUpgradeStartTime ""
                                                                                                                                                                                        :description ""}}
                                                                                                                                                          :name ""
                                                                                                                                                          :nodePoolId ""
                                                                                                                                                          :projectId ""
                                                                                                                                                          :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 250

{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  management: {
    autoRepair: false,
    autoUpgrade: false,
    upgradeOptions: {
      autoUpgradeStartTime: '',
      description: ''
    }
  },
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {autoUpgradeStartTime: '', description: ''}
    },
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"name":"","nodePoolId":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "management": {\n    "autoRepair": false,\n    "autoUpgrade": false,\n    "upgradeOptions": {\n      "autoUpgradeStartTime": "",\n      "description": ""\n    }\n  },\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement',
  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({
  clusterId: '',
  management: {
    autoRepair: false,
    autoUpgrade: false,
    upgradeOptions: {autoUpgradeStartTime: '', description: ''}
  },
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {autoUpgradeStartTime: '', description: ''}
    },
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  management: {
    autoRepair: false,
    autoUpgrade: false,
    upgradeOptions: {
      autoUpgradeStartTime: '',
      description: ''
    }
  },
  name: '',
  nodePoolId: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    management: {
      autoRepair: false,
      autoUpgrade: false,
      upgradeOptions: {autoUpgradeStartTime: '', description: ''}
    },
    name: '',
    nodePoolId: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"name":"","nodePoolId":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"management": @{ @"autoRepair": @NO, @"autoUpgrade": @NO, @"upgradeOptions": @{ @"autoUpgradeStartTime": @"", @"description": @"" } },
                              @"name": @"",
                              @"nodePoolId": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement",
  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([
    'clusterId' => '',
    'management' => [
        'autoRepair' => null,
        'autoUpgrade' => null,
        'upgradeOptions' => [
                'autoUpgradeStartTime' => '',
                'description' => ''
        ]
    ],
    'name' => '',
    'nodePoolId' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement', [
  'body' => '{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'management' => [
    'autoRepair' => null,
    'autoUpgrade' => null,
    'upgradeOptions' => [
        'autoUpgradeStartTime' => '',
        'description' => ''
    ]
  ],
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'management' => [
    'autoRepair' => null,
    'autoUpgrade' => null,
    'upgradeOptions' => [
        'autoUpgradeStartTime' => '',
        'description' => ''
    ]
  ],
  'name' => '',
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement"

payload = {
    "clusterId": "",
    "management": {
        "autoRepair": False,
        "autoUpgrade": False,
        "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
        }
    },
    "name": "",
    "nodePoolId": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement"

payload <- "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement")

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  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"management\": {\n    \"autoRepair\": false,\n    \"autoUpgrade\": false,\n    \"upgradeOptions\": {\n      \"autoUpgradeStartTime\": \"\",\n      \"description\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement";

    let payload = json!({
        "clusterId": "",
        "management": json!({
            "autoRepair": false,
            "autoUpgrade": false,
            "upgradeOptions": json!({
                "autoUpgradeStartTime": "",
                "description": ""
            })
        }),
        "name": "",
        "nodePoolId": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "management": {
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": {
      "autoUpgradeStartTime": "",
      "description": ""
    }
  },
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "management": {\n    "autoRepair": false,\n    "autoUpgrade": false,\n    "upgradeOptions": {\n      "autoUpgradeStartTime": "",\n      "description": ""\n    }\n  },\n  "name": "",\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "management": [
    "autoRepair": false,
    "autoUpgrade": false,
    "upgradeOptions": [
      "autoUpgradeStartTime": "",
      "description": ""
    ]
  ],
  "name": "",
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setManagement")! 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 container.projects.zones.clusters.nodePools.setSize
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize
QUERY PARAMS

projectId
zone
clusterId
nodePoolId
BODY json

{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize");

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize" {:content-type :json
                                                                                                                                      :form-params {:clusterId ""
                                                                                                                                                    :name ""
                                                                                                                                                    :nodeCount 0
                                                                                                                                                    :nodePoolId ""
                                                                                                                                                    :projectId ""
                                                                                                                                                    :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 106

{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  name: '',
  nodeCount: 0,
  nodePoolId: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', nodeCount: 0, nodePoolId: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","nodeCount":0,"nodePoolId":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "name": "",\n  "nodeCount": 0,\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize',
  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({clusterId: '', name: '', nodeCount: 0, nodePoolId: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', name: '', nodeCount: 0, nodePoolId: '', projectId: '', zone: ''},
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  name: '',
  nodeCount: 0,
  nodePoolId: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', nodeCount: 0, nodePoolId: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","nodeCount":0,"nodePoolId":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"name": @"",
                              @"nodeCount": @0,
                              @"nodePoolId": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize",
  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([
    'clusterId' => '',
    'name' => '',
    'nodeCount' => 0,
    'nodePoolId' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize', [
  'body' => '{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'name' => '',
  'nodeCount' => 0,
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'name' => '',
  'nodeCount' => 0,
  'nodePoolId' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize"

payload = {
    "clusterId": "",
    "name": "",
    "nodeCount": 0,
    "nodePoolId": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize"

payload <- "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize")

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"nodeCount\": 0,\n  \"nodePoolId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize";

    let payload = json!({
        "clusterId": "",
        "name": "",
        "nodeCount": 0,
        "nodePoolId": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "name": "",\n  "nodeCount": 0,\n  "nodePoolId": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "name": "",
  "nodeCount": 0,
  "nodePoolId": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/setSize")! 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 container.projects.zones.clusters.nodePools.update
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update
QUERY PARAMS

projectId
zone
clusterId
nodePoolId
BODY json

{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update");

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  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update" {:content-type :json
                                                                                                                                     :form-params {:clusterId ""
                                                                                                                                                   :confidentialNodes {:enabled false}
                                                                                                                                                   :etag ""
                                                                                                                                                   :fastSocket {:enabled false}
                                                                                                                                                   :gcfsConfig {:enabled false}
                                                                                                                                                   :gvnic {:enabled false}
                                                                                                                                                   :imageType ""
                                                                                                                                                   :kubeletConfig {:cpuCfsQuota false
                                                                                                                                                                   :cpuCfsQuotaPeriod ""
                                                                                                                                                                   :cpuManagerPolicy ""
                                                                                                                                                                   :podPidsLimit ""}
                                                                                                                                                   :labels {:labels {}}
                                                                                                                                                   :linuxNodeConfig {:cgroupMode ""
                                                                                                                                                                     :sysctls {}}
                                                                                                                                                   :locations []
                                                                                                                                                   :loggingConfig {:variantConfig {:variant ""}}
                                                                                                                                                   :name ""
                                                                                                                                                   :nodeNetworkConfig {:createPodRange false
                                                                                                                                                                       :enablePrivateNodes false
                                                                                                                                                                       :networkPerformanceConfig {:externalIpEgressBandwidthTier ""
                                                                                                                                                                                                  :totalEgressBandwidthTier ""}
                                                                                                                                                                       :podCidrOverprovisionConfig {:disable false}
                                                                                                                                                                       :podIpv4CidrBlock ""
                                                                                                                                                                       :podRange ""}
                                                                                                                                                   :nodePoolId ""
                                                                                                                                                   :nodeVersion ""
                                                                                                                                                   :projectId ""
                                                                                                                                                   :resourceLabels {:labels {}}
                                                                                                                                                   :tags {:tags []}
                                                                                                                                                   :taints {:taints [{:effect ""
                                                                                                                                                                      :key ""
                                                                                                                                                                      :value ""}]}
                                                                                                                                                   :upgradeSettings {:blueGreenSettings {:nodePoolSoakDuration ""
                                                                                                                                                                                         :standardRolloutPolicy {:batchNodeCount 0
                                                                                                                                                                                                                 :batchPercentage ""
                                                                                                                                                                                                                 :batchSoakDuration ""}}
                                                                                                                                                                     :maxSurge 0
                                                                                                                                                                     :maxUnavailable 0
                                                                                                                                                                     :strategy ""}
                                                                                                                                                   :windowsNodeConfig {:osVersion ""}
                                                                                                                                                   :workloadMetadataConfig {:mode ""
                                                                                                                                                                            :nodeMetadata ""}
                                                                                                                                                   :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1586

{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  confidentialNodes: {
    enabled: false
  },
  etag: '',
  fastSocket: {
    enabled: false
  },
  gcfsConfig: {
    enabled: false
  },
  gvnic: {
    enabled: false
  },
  imageType: '',
  kubeletConfig: {
    cpuCfsQuota: false,
    cpuCfsQuotaPeriod: '',
    cpuManagerPolicy: '',
    podPidsLimit: ''
  },
  labels: {
    labels: {}
  },
  linuxNodeConfig: {
    cgroupMode: '',
    sysctls: {}
  },
  locations: [],
  loggingConfig: {
    variantConfig: {
      variant: ''
    }
  },
  name: '',
  nodeNetworkConfig: {
    createPodRange: false,
    enablePrivateNodes: false,
    networkPerformanceConfig: {
      externalIpEgressBandwidthTier: '',
      totalEgressBandwidthTier: ''
    },
    podCidrOverprovisionConfig: {
      disable: false
    },
    podIpv4CidrBlock: '',
    podRange: ''
  },
  nodePoolId: '',
  nodeVersion: '',
  projectId: '',
  resourceLabels: {
    labels: {}
  },
  tags: {
    tags: []
  },
  taints: {
    taints: [
      {
        effect: '',
        key: '',
        value: ''
      }
    ]
  },
  upgradeSettings: {
    blueGreenSettings: {
      nodePoolSoakDuration: '',
      standardRolloutPolicy: {
        batchNodeCount: 0,
        batchPercentage: '',
        batchSoakDuration: ''
      }
    },
    maxSurge: 0,
    maxUnavailable: 0,
    strategy: ''
  },
  windowsNodeConfig: {
    osVersion: ''
  },
  workloadMetadataConfig: {
    mode: '',
    nodeMetadata: ''
  },
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    confidentialNodes: {enabled: false},
    etag: '',
    fastSocket: {enabled: false},
    gcfsConfig: {enabled: false},
    gvnic: {enabled: false},
    imageType: '',
    kubeletConfig: {
      cpuCfsQuota: false,
      cpuCfsQuotaPeriod: '',
      cpuManagerPolicy: '',
      podPidsLimit: ''
    },
    labels: {labels: {}},
    linuxNodeConfig: {cgroupMode: '', sysctls: {}},
    locations: [],
    loggingConfig: {variantConfig: {variant: ''}},
    name: '',
    nodeNetworkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
      podCidrOverprovisionConfig: {disable: false},
      podIpv4CidrBlock: '',
      podRange: ''
    },
    nodePoolId: '',
    nodeVersion: '',
    projectId: '',
    resourceLabels: {labels: {}},
    tags: {tags: []},
    taints: {taints: [{effect: '', key: '', value: ''}]},
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    windowsNodeConfig: {osVersion: ''},
    workloadMetadataConfig: {mode: '', nodeMetadata: ''},
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","confidentialNodes":{"enabled":false},"etag":"","fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{"labels":{}},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"locations":[],"loggingConfig":{"variantConfig":{"variant":""}},"name":"","nodeNetworkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{"disable":false},"podIpv4CidrBlock":"","podRange":""},"nodePoolId":"","nodeVersion":"","projectId":"","resourceLabels":{"labels":{}},"tags":{"tags":[]},"taints":{"taints":[{"effect":"","key":"","value":""}]},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""},"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""},"zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "confidentialNodes": {\n    "enabled": false\n  },\n  "etag": "",\n  "fastSocket": {\n    "enabled": false\n  },\n  "gcfsConfig": {\n    "enabled": false\n  },\n  "gvnic": {\n    "enabled": false\n  },\n  "imageType": "",\n  "kubeletConfig": {\n    "cpuCfsQuota": false,\n    "cpuCfsQuotaPeriod": "",\n    "cpuManagerPolicy": "",\n    "podPidsLimit": ""\n  },\n  "labels": {\n    "labels": {}\n  },\n  "linuxNodeConfig": {\n    "cgroupMode": "",\n    "sysctls": {}\n  },\n  "locations": [],\n  "loggingConfig": {\n    "variantConfig": {\n      "variant": ""\n    }\n  },\n  "name": "",\n  "nodeNetworkConfig": {\n    "createPodRange": false,\n    "enablePrivateNodes": false,\n    "networkPerformanceConfig": {\n      "externalIpEgressBandwidthTier": "",\n      "totalEgressBandwidthTier": ""\n    },\n    "podCidrOverprovisionConfig": {\n      "disable": false\n    },\n    "podIpv4CidrBlock": "",\n    "podRange": ""\n  },\n  "nodePoolId": "",\n  "nodeVersion": "",\n  "projectId": "",\n  "resourceLabels": {\n    "labels": {}\n  },\n  "tags": {\n    "tags": []\n  },\n  "taints": {\n    "taints": [\n      {\n        "effect": "",\n        "key": "",\n        "value": ""\n      }\n    ]\n  },\n  "upgradeSettings": {\n    "blueGreenSettings": {\n      "nodePoolSoakDuration": "",\n      "standardRolloutPolicy": {\n        "batchNodeCount": 0,\n        "batchPercentage": "",\n        "batchSoakDuration": ""\n      }\n    },\n    "maxSurge": 0,\n    "maxUnavailable": 0,\n    "strategy": ""\n  },\n  "windowsNodeConfig": {\n    "osVersion": ""\n  },\n  "workloadMetadataConfig": {\n    "mode": "",\n    "nodeMetadata": ""\n  },\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update',
  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({
  clusterId: '',
  confidentialNodes: {enabled: false},
  etag: '',
  fastSocket: {enabled: false},
  gcfsConfig: {enabled: false},
  gvnic: {enabled: false},
  imageType: '',
  kubeletConfig: {
    cpuCfsQuota: false,
    cpuCfsQuotaPeriod: '',
    cpuManagerPolicy: '',
    podPidsLimit: ''
  },
  labels: {labels: {}},
  linuxNodeConfig: {cgroupMode: '', sysctls: {}},
  locations: [],
  loggingConfig: {variantConfig: {variant: ''}},
  name: '',
  nodeNetworkConfig: {
    createPodRange: false,
    enablePrivateNodes: false,
    networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
    podCidrOverprovisionConfig: {disable: false},
    podIpv4CidrBlock: '',
    podRange: ''
  },
  nodePoolId: '',
  nodeVersion: '',
  projectId: '',
  resourceLabels: {labels: {}},
  tags: {tags: []},
  taints: {taints: [{effect: '', key: '', value: ''}]},
  upgradeSettings: {
    blueGreenSettings: {
      nodePoolSoakDuration: '',
      standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
    },
    maxSurge: 0,
    maxUnavailable: 0,
    strategy: ''
  },
  windowsNodeConfig: {osVersion: ''},
  workloadMetadataConfig: {mode: '', nodeMetadata: ''},
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    confidentialNodes: {enabled: false},
    etag: '',
    fastSocket: {enabled: false},
    gcfsConfig: {enabled: false},
    gvnic: {enabled: false},
    imageType: '',
    kubeletConfig: {
      cpuCfsQuota: false,
      cpuCfsQuotaPeriod: '',
      cpuManagerPolicy: '',
      podPidsLimit: ''
    },
    labels: {labels: {}},
    linuxNodeConfig: {cgroupMode: '', sysctls: {}},
    locations: [],
    loggingConfig: {variantConfig: {variant: ''}},
    name: '',
    nodeNetworkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
      podCidrOverprovisionConfig: {disable: false},
      podIpv4CidrBlock: '',
      podRange: ''
    },
    nodePoolId: '',
    nodeVersion: '',
    projectId: '',
    resourceLabels: {labels: {}},
    tags: {tags: []},
    taints: {taints: [{effect: '', key: '', value: ''}]},
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    windowsNodeConfig: {osVersion: ''},
    workloadMetadataConfig: {mode: '', nodeMetadata: ''},
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  confidentialNodes: {
    enabled: false
  },
  etag: '',
  fastSocket: {
    enabled: false
  },
  gcfsConfig: {
    enabled: false
  },
  gvnic: {
    enabled: false
  },
  imageType: '',
  kubeletConfig: {
    cpuCfsQuota: false,
    cpuCfsQuotaPeriod: '',
    cpuManagerPolicy: '',
    podPidsLimit: ''
  },
  labels: {
    labels: {}
  },
  linuxNodeConfig: {
    cgroupMode: '',
    sysctls: {}
  },
  locations: [],
  loggingConfig: {
    variantConfig: {
      variant: ''
    }
  },
  name: '',
  nodeNetworkConfig: {
    createPodRange: false,
    enablePrivateNodes: false,
    networkPerformanceConfig: {
      externalIpEgressBandwidthTier: '',
      totalEgressBandwidthTier: ''
    },
    podCidrOverprovisionConfig: {
      disable: false
    },
    podIpv4CidrBlock: '',
    podRange: ''
  },
  nodePoolId: '',
  nodeVersion: '',
  projectId: '',
  resourceLabels: {
    labels: {}
  },
  tags: {
    tags: []
  },
  taints: {
    taints: [
      {
        effect: '',
        key: '',
        value: ''
      }
    ]
  },
  upgradeSettings: {
    blueGreenSettings: {
      nodePoolSoakDuration: '',
      standardRolloutPolicy: {
        batchNodeCount: 0,
        batchPercentage: '',
        batchSoakDuration: ''
      }
    },
    maxSurge: 0,
    maxUnavailable: 0,
    strategy: ''
  },
  windowsNodeConfig: {
    osVersion: ''
  },
  workloadMetadataConfig: {
    mode: '',
    nodeMetadata: ''
  },
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    confidentialNodes: {enabled: false},
    etag: '',
    fastSocket: {enabled: false},
    gcfsConfig: {enabled: false},
    gvnic: {enabled: false},
    imageType: '',
    kubeletConfig: {
      cpuCfsQuota: false,
      cpuCfsQuotaPeriod: '',
      cpuManagerPolicy: '',
      podPidsLimit: ''
    },
    labels: {labels: {}},
    linuxNodeConfig: {cgroupMode: '', sysctls: {}},
    locations: [],
    loggingConfig: {variantConfig: {variant: ''}},
    name: '',
    nodeNetworkConfig: {
      createPodRange: false,
      enablePrivateNodes: false,
      networkPerformanceConfig: {externalIpEgressBandwidthTier: '', totalEgressBandwidthTier: ''},
      podCidrOverprovisionConfig: {disable: false},
      podIpv4CidrBlock: '',
      podRange: ''
    },
    nodePoolId: '',
    nodeVersion: '',
    projectId: '',
    resourceLabels: {labels: {}},
    tags: {tags: []},
    taints: {taints: [{effect: '', key: '', value: ''}]},
    upgradeSettings: {
      blueGreenSettings: {
        nodePoolSoakDuration: '',
        standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
      },
      maxSurge: 0,
      maxUnavailable: 0,
      strategy: ''
    },
    windowsNodeConfig: {osVersion: ''},
    workloadMetadataConfig: {mode: '', nodeMetadata: ''},
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","confidentialNodes":{"enabled":false},"etag":"","fastSocket":{"enabled":false},"gcfsConfig":{"enabled":false},"gvnic":{"enabled":false},"imageType":"","kubeletConfig":{"cpuCfsQuota":false,"cpuCfsQuotaPeriod":"","cpuManagerPolicy":"","podPidsLimit":""},"labels":{"labels":{}},"linuxNodeConfig":{"cgroupMode":"","sysctls":{}},"locations":[],"loggingConfig":{"variantConfig":{"variant":""}},"name":"","nodeNetworkConfig":{"createPodRange":false,"enablePrivateNodes":false,"networkPerformanceConfig":{"externalIpEgressBandwidthTier":"","totalEgressBandwidthTier":""},"podCidrOverprovisionConfig":{"disable":false},"podIpv4CidrBlock":"","podRange":""},"nodePoolId":"","nodeVersion":"","projectId":"","resourceLabels":{"labels":{}},"tags":{"tags":[]},"taints":{"taints":[{"effect":"","key":"","value":""}]},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""},"windowsNodeConfig":{"osVersion":""},"workloadMetadataConfig":{"mode":"","nodeMetadata":""},"zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"confidentialNodes": @{ @"enabled": @NO },
                              @"etag": @"",
                              @"fastSocket": @{ @"enabled": @NO },
                              @"gcfsConfig": @{ @"enabled": @NO },
                              @"gvnic": @{ @"enabled": @NO },
                              @"imageType": @"",
                              @"kubeletConfig": @{ @"cpuCfsQuota": @NO, @"cpuCfsQuotaPeriod": @"", @"cpuManagerPolicy": @"", @"podPidsLimit": @"" },
                              @"labels": @{ @"labels": @{  } },
                              @"linuxNodeConfig": @{ @"cgroupMode": @"", @"sysctls": @{  } },
                              @"locations": @[  ],
                              @"loggingConfig": @{ @"variantConfig": @{ @"variant": @"" } },
                              @"name": @"",
                              @"nodeNetworkConfig": @{ @"createPodRange": @NO, @"enablePrivateNodes": @NO, @"networkPerformanceConfig": @{ @"externalIpEgressBandwidthTier": @"", @"totalEgressBandwidthTier": @"" }, @"podCidrOverprovisionConfig": @{ @"disable": @NO }, @"podIpv4CidrBlock": @"", @"podRange": @"" },
                              @"nodePoolId": @"",
                              @"nodeVersion": @"",
                              @"projectId": @"",
                              @"resourceLabels": @{ @"labels": @{  } },
                              @"tags": @{ @"tags": @[  ] },
                              @"taints": @{ @"taints": @[ @{ @"effect": @"", @"key": @"", @"value": @"" } ] },
                              @"upgradeSettings": @{ @"blueGreenSettings": @{ @"nodePoolSoakDuration": @"", @"standardRolloutPolicy": @{ @"batchNodeCount": @0, @"batchPercentage": @"", @"batchSoakDuration": @"" } }, @"maxSurge": @0, @"maxUnavailable": @0, @"strategy": @"" },
                              @"windowsNodeConfig": @{ @"osVersion": @"" },
                              @"workloadMetadataConfig": @{ @"mode": @"", @"nodeMetadata": @"" },
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update",
  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([
    'clusterId' => '',
    'confidentialNodes' => [
        'enabled' => null
    ],
    'etag' => '',
    'fastSocket' => [
        'enabled' => null
    ],
    'gcfsConfig' => [
        'enabled' => null
    ],
    'gvnic' => [
        'enabled' => null
    ],
    'imageType' => '',
    'kubeletConfig' => [
        'cpuCfsQuota' => null,
        'cpuCfsQuotaPeriod' => '',
        'cpuManagerPolicy' => '',
        'podPidsLimit' => ''
    ],
    'labels' => [
        'labels' => [
                
        ]
    ],
    'linuxNodeConfig' => [
        'cgroupMode' => '',
        'sysctls' => [
                
        ]
    ],
    'locations' => [
        
    ],
    'loggingConfig' => [
        'variantConfig' => [
                'variant' => ''
        ]
    ],
    'name' => '',
    'nodeNetworkConfig' => [
        'createPodRange' => null,
        'enablePrivateNodes' => null,
        'networkPerformanceConfig' => [
                'externalIpEgressBandwidthTier' => '',
                'totalEgressBandwidthTier' => ''
        ],
        'podCidrOverprovisionConfig' => [
                'disable' => null
        ],
        'podIpv4CidrBlock' => '',
        'podRange' => ''
    ],
    'nodePoolId' => '',
    'nodeVersion' => '',
    'projectId' => '',
    'resourceLabels' => [
        'labels' => [
                
        ]
    ],
    'tags' => [
        'tags' => [
                
        ]
    ],
    'taints' => [
        'taints' => [
                [
                                'effect' => '',
                                'key' => '',
                                'value' => ''
                ]
        ]
    ],
    'upgradeSettings' => [
        'blueGreenSettings' => [
                'nodePoolSoakDuration' => '',
                'standardRolloutPolicy' => [
                                'batchNodeCount' => 0,
                                'batchPercentage' => '',
                                'batchSoakDuration' => ''
                ]
        ],
        'maxSurge' => 0,
        'maxUnavailable' => 0,
        'strategy' => ''
    ],
    'windowsNodeConfig' => [
        'osVersion' => ''
    ],
    'workloadMetadataConfig' => [
        'mode' => '',
        'nodeMetadata' => ''
    ],
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update', [
  'body' => '{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'confidentialNodes' => [
    'enabled' => null
  ],
  'etag' => '',
  'fastSocket' => [
    'enabled' => null
  ],
  'gcfsConfig' => [
    'enabled' => null
  ],
  'gvnic' => [
    'enabled' => null
  ],
  'imageType' => '',
  'kubeletConfig' => [
    'cpuCfsQuota' => null,
    'cpuCfsQuotaPeriod' => '',
    'cpuManagerPolicy' => '',
    'podPidsLimit' => ''
  ],
  'labels' => [
    'labels' => [
        
    ]
  ],
  'linuxNodeConfig' => [
    'cgroupMode' => '',
    'sysctls' => [
        
    ]
  ],
  'locations' => [
    
  ],
  'loggingConfig' => [
    'variantConfig' => [
        'variant' => ''
    ]
  ],
  'name' => '',
  'nodeNetworkConfig' => [
    'createPodRange' => null,
    'enablePrivateNodes' => null,
    'networkPerformanceConfig' => [
        'externalIpEgressBandwidthTier' => '',
        'totalEgressBandwidthTier' => ''
    ],
    'podCidrOverprovisionConfig' => [
        'disable' => null
    ],
    'podIpv4CidrBlock' => '',
    'podRange' => ''
  ],
  'nodePoolId' => '',
  'nodeVersion' => '',
  'projectId' => '',
  'resourceLabels' => [
    'labels' => [
        
    ]
  ],
  'tags' => [
    'tags' => [
        
    ]
  ],
  'taints' => [
    'taints' => [
        [
                'effect' => '',
                'key' => '',
                'value' => ''
        ]
    ]
  ],
  'upgradeSettings' => [
    'blueGreenSettings' => [
        'nodePoolSoakDuration' => '',
        'standardRolloutPolicy' => [
                'batchNodeCount' => 0,
                'batchPercentage' => '',
                'batchSoakDuration' => ''
        ]
    ],
    'maxSurge' => 0,
    'maxUnavailable' => 0,
    'strategy' => ''
  ],
  'windowsNodeConfig' => [
    'osVersion' => ''
  ],
  'workloadMetadataConfig' => [
    'mode' => '',
    'nodeMetadata' => ''
  ],
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'confidentialNodes' => [
    'enabled' => null
  ],
  'etag' => '',
  'fastSocket' => [
    'enabled' => null
  ],
  'gcfsConfig' => [
    'enabled' => null
  ],
  'gvnic' => [
    'enabled' => null
  ],
  'imageType' => '',
  'kubeletConfig' => [
    'cpuCfsQuota' => null,
    'cpuCfsQuotaPeriod' => '',
    'cpuManagerPolicy' => '',
    'podPidsLimit' => ''
  ],
  'labels' => [
    'labels' => [
        
    ]
  ],
  'linuxNodeConfig' => [
    'cgroupMode' => '',
    'sysctls' => [
        
    ]
  ],
  'locations' => [
    
  ],
  'loggingConfig' => [
    'variantConfig' => [
        'variant' => ''
    ]
  ],
  'name' => '',
  'nodeNetworkConfig' => [
    'createPodRange' => null,
    'enablePrivateNodes' => null,
    'networkPerformanceConfig' => [
        'externalIpEgressBandwidthTier' => '',
        'totalEgressBandwidthTier' => ''
    ],
    'podCidrOverprovisionConfig' => [
        'disable' => null
    ],
    'podIpv4CidrBlock' => '',
    'podRange' => ''
  ],
  'nodePoolId' => '',
  'nodeVersion' => '',
  'projectId' => '',
  'resourceLabels' => [
    'labels' => [
        
    ]
  ],
  'tags' => [
    'tags' => [
        
    ]
  ],
  'taints' => [
    'taints' => [
        [
                'effect' => '',
                'key' => '',
                'value' => ''
        ]
    ]
  ],
  'upgradeSettings' => [
    'blueGreenSettings' => [
        'nodePoolSoakDuration' => '',
        'standardRolloutPolicy' => [
                'batchNodeCount' => 0,
                'batchPercentage' => '',
                'batchSoakDuration' => ''
        ]
    ],
    'maxSurge' => 0,
    'maxUnavailable' => 0,
    'strategy' => ''
  ],
  'windowsNodeConfig' => [
    'osVersion' => ''
  ],
  'workloadMetadataConfig' => [
    'mode' => '',
    'nodeMetadata' => ''
  ],
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update"

payload = {
    "clusterId": "",
    "confidentialNodes": { "enabled": False },
    "etag": "",
    "fastSocket": { "enabled": False },
    "gcfsConfig": { "enabled": False },
    "gvnic": { "enabled": False },
    "imageType": "",
    "kubeletConfig": {
        "cpuCfsQuota": False,
        "cpuCfsQuotaPeriod": "",
        "cpuManagerPolicy": "",
        "podPidsLimit": ""
    },
    "labels": { "labels": {} },
    "linuxNodeConfig": {
        "cgroupMode": "",
        "sysctls": {}
    },
    "locations": [],
    "loggingConfig": { "variantConfig": { "variant": "" } },
    "name": "",
    "nodeNetworkConfig": {
        "createPodRange": False,
        "enablePrivateNodes": False,
        "networkPerformanceConfig": {
            "externalIpEgressBandwidthTier": "",
            "totalEgressBandwidthTier": ""
        },
        "podCidrOverprovisionConfig": { "disable": False },
        "podIpv4CidrBlock": "",
        "podRange": ""
    },
    "nodePoolId": "",
    "nodeVersion": "",
    "projectId": "",
    "resourceLabels": { "labels": {} },
    "tags": { "tags": [] },
    "taints": { "taints": [
            {
                "effect": "",
                "key": "",
                "value": ""
            }
        ] },
    "upgradeSettings": {
        "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
                "batchNodeCount": 0,
                "batchPercentage": "",
                "batchSoakDuration": ""
            }
        },
        "maxSurge": 0,
        "maxUnavailable": 0,
        "strategy": ""
    },
    "windowsNodeConfig": { "osVersion": "" },
    "workloadMetadataConfig": {
        "mode": "",
        "nodeMetadata": ""
    },
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update"

payload <- "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update")

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  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"confidentialNodes\": {\n    \"enabled\": false\n  },\n  \"etag\": \"\",\n  \"fastSocket\": {\n    \"enabled\": false\n  },\n  \"gcfsConfig\": {\n    \"enabled\": false\n  },\n  \"gvnic\": {\n    \"enabled\": false\n  },\n  \"imageType\": \"\",\n  \"kubeletConfig\": {\n    \"cpuCfsQuota\": false,\n    \"cpuCfsQuotaPeriod\": \"\",\n    \"cpuManagerPolicy\": \"\",\n    \"podPidsLimit\": \"\"\n  },\n  \"labels\": {\n    \"labels\": {}\n  },\n  \"linuxNodeConfig\": {\n    \"cgroupMode\": \"\",\n    \"sysctls\": {}\n  },\n  \"locations\": [],\n  \"loggingConfig\": {\n    \"variantConfig\": {\n      \"variant\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"nodeNetworkConfig\": {\n    \"createPodRange\": false,\n    \"enablePrivateNodes\": false,\n    \"networkPerformanceConfig\": {\n      \"externalIpEgressBandwidthTier\": \"\",\n      \"totalEgressBandwidthTier\": \"\"\n    },\n    \"podCidrOverprovisionConfig\": {\n      \"disable\": false\n    },\n    \"podIpv4CidrBlock\": \"\",\n    \"podRange\": \"\"\n  },\n  \"nodePoolId\": \"\",\n  \"nodeVersion\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {\n    \"labels\": {}\n  },\n  \"tags\": {\n    \"tags\": []\n  },\n  \"taints\": {\n    \"taints\": [\n      {\n        \"effect\": \"\",\n        \"key\": \"\",\n        \"value\": \"\"\n      }\n    ]\n  },\n  \"upgradeSettings\": {\n    \"blueGreenSettings\": {\n      \"nodePoolSoakDuration\": \"\",\n      \"standardRolloutPolicy\": {\n        \"batchNodeCount\": 0,\n        \"batchPercentage\": \"\",\n        \"batchSoakDuration\": \"\"\n      }\n    },\n    \"maxSurge\": 0,\n    \"maxUnavailable\": 0,\n    \"strategy\": \"\"\n  },\n  \"windowsNodeConfig\": {\n    \"osVersion\": \"\"\n  },\n  \"workloadMetadataConfig\": {\n    \"mode\": \"\",\n    \"nodeMetadata\": \"\"\n  },\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update";

    let payload = json!({
        "clusterId": "",
        "confidentialNodes": json!({"enabled": false}),
        "etag": "",
        "fastSocket": json!({"enabled": false}),
        "gcfsConfig": json!({"enabled": false}),
        "gvnic": json!({"enabled": false}),
        "imageType": "",
        "kubeletConfig": json!({
            "cpuCfsQuota": false,
            "cpuCfsQuotaPeriod": "",
            "cpuManagerPolicy": "",
            "podPidsLimit": ""
        }),
        "labels": json!({"labels": json!({})}),
        "linuxNodeConfig": json!({
            "cgroupMode": "",
            "sysctls": json!({})
        }),
        "locations": (),
        "loggingConfig": json!({"variantConfig": json!({"variant": ""})}),
        "name": "",
        "nodeNetworkConfig": json!({
            "createPodRange": false,
            "enablePrivateNodes": false,
            "networkPerformanceConfig": json!({
                "externalIpEgressBandwidthTier": "",
                "totalEgressBandwidthTier": ""
            }),
            "podCidrOverprovisionConfig": json!({"disable": false}),
            "podIpv4CidrBlock": "",
            "podRange": ""
        }),
        "nodePoolId": "",
        "nodeVersion": "",
        "projectId": "",
        "resourceLabels": json!({"labels": json!({})}),
        "tags": json!({"tags": ()}),
        "taints": json!({"taints": (
                json!({
                    "effect": "",
                    "key": "",
                    "value": ""
                })
            )}),
        "upgradeSettings": json!({
            "blueGreenSettings": json!({
                "nodePoolSoakDuration": "",
                "standardRolloutPolicy": json!({
                    "batchNodeCount": 0,
                    "batchPercentage": "",
                    "batchSoakDuration": ""
                })
            }),
            "maxSurge": 0,
            "maxUnavailable": 0,
            "strategy": ""
        }),
        "windowsNodeConfig": json!({"osVersion": ""}),
        "workloadMetadataConfig": json!({
            "mode": "",
            "nodeMetadata": ""
        }),
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}'
echo '{
  "clusterId": "",
  "confidentialNodes": {
    "enabled": false
  },
  "etag": "",
  "fastSocket": {
    "enabled": false
  },
  "gcfsConfig": {
    "enabled": false
  },
  "gvnic": {
    "enabled": false
  },
  "imageType": "",
  "kubeletConfig": {
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  },
  "labels": {
    "labels": {}
  },
  "linuxNodeConfig": {
    "cgroupMode": "",
    "sysctls": {}
  },
  "locations": [],
  "loggingConfig": {
    "variantConfig": {
      "variant": ""
    }
  },
  "name": "",
  "nodeNetworkConfig": {
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": {
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    },
    "podCidrOverprovisionConfig": {
      "disable": false
    },
    "podIpv4CidrBlock": "",
    "podRange": ""
  },
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": {
    "labels": {}
  },
  "tags": {
    "tags": []
  },
  "taints": {
    "taints": [
      {
        "effect": "",
        "key": "",
        "value": ""
      }
    ]
  },
  "upgradeSettings": {
    "blueGreenSettings": {
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": {
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      }
    },
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  },
  "windowsNodeConfig": {
    "osVersion": ""
  },
  "workloadMetadataConfig": {
    "mode": "",
    "nodeMetadata": ""
  },
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "confidentialNodes": {\n    "enabled": false\n  },\n  "etag": "",\n  "fastSocket": {\n    "enabled": false\n  },\n  "gcfsConfig": {\n    "enabled": false\n  },\n  "gvnic": {\n    "enabled": false\n  },\n  "imageType": "",\n  "kubeletConfig": {\n    "cpuCfsQuota": false,\n    "cpuCfsQuotaPeriod": "",\n    "cpuManagerPolicy": "",\n    "podPidsLimit": ""\n  },\n  "labels": {\n    "labels": {}\n  },\n  "linuxNodeConfig": {\n    "cgroupMode": "",\n    "sysctls": {}\n  },\n  "locations": [],\n  "loggingConfig": {\n    "variantConfig": {\n      "variant": ""\n    }\n  },\n  "name": "",\n  "nodeNetworkConfig": {\n    "createPodRange": false,\n    "enablePrivateNodes": false,\n    "networkPerformanceConfig": {\n      "externalIpEgressBandwidthTier": "",\n      "totalEgressBandwidthTier": ""\n    },\n    "podCidrOverprovisionConfig": {\n      "disable": false\n    },\n    "podIpv4CidrBlock": "",\n    "podRange": ""\n  },\n  "nodePoolId": "",\n  "nodeVersion": "",\n  "projectId": "",\n  "resourceLabels": {\n    "labels": {}\n  },\n  "tags": {\n    "tags": []\n  },\n  "taints": {\n    "taints": [\n      {\n        "effect": "",\n        "key": "",\n        "value": ""\n      }\n    ]\n  },\n  "upgradeSettings": {\n    "blueGreenSettings": {\n      "nodePoolSoakDuration": "",\n      "standardRolloutPolicy": {\n        "batchNodeCount": 0,\n        "batchPercentage": "",\n        "batchSoakDuration": ""\n      }\n    },\n    "maxSurge": 0,\n    "maxUnavailable": 0,\n    "strategy": ""\n  },\n  "windowsNodeConfig": {\n    "osVersion": ""\n  },\n  "workloadMetadataConfig": {\n    "mode": "",\n    "nodeMetadata": ""\n  },\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "confidentialNodes": ["enabled": false],
  "etag": "",
  "fastSocket": ["enabled": false],
  "gcfsConfig": ["enabled": false],
  "gvnic": ["enabled": false],
  "imageType": "",
  "kubeletConfig": [
    "cpuCfsQuota": false,
    "cpuCfsQuotaPeriod": "",
    "cpuManagerPolicy": "",
    "podPidsLimit": ""
  ],
  "labels": ["labels": []],
  "linuxNodeConfig": [
    "cgroupMode": "",
    "sysctls": []
  ],
  "locations": [],
  "loggingConfig": ["variantConfig": ["variant": ""]],
  "name": "",
  "nodeNetworkConfig": [
    "createPodRange": false,
    "enablePrivateNodes": false,
    "networkPerformanceConfig": [
      "externalIpEgressBandwidthTier": "",
      "totalEgressBandwidthTier": ""
    ],
    "podCidrOverprovisionConfig": ["disable": false],
    "podIpv4CidrBlock": "",
    "podRange": ""
  ],
  "nodePoolId": "",
  "nodeVersion": "",
  "projectId": "",
  "resourceLabels": ["labels": []],
  "tags": ["tags": []],
  "taints": ["taints": [
      [
        "effect": "",
        "key": "",
        "value": ""
      ]
    ]],
  "upgradeSettings": [
    "blueGreenSettings": [
      "nodePoolSoakDuration": "",
      "standardRolloutPolicy": [
        "batchNodeCount": 0,
        "batchPercentage": "",
        "batchSoakDuration": ""
      ]
    ],
    "maxSurge": 0,
    "maxUnavailable": 0,
    "strategy": ""
  ],
  "windowsNodeConfig": ["osVersion": ""],
  "workloadMetadataConfig": [
    "mode": "",
    "nodeMetadata": ""
  ],
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/nodePools/:nodePoolId/update")! 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 container.projects.zones.clusters.resourceLabels
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels");

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  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels" {:content-type :json
                                                                                                                       :form-params {:clusterId ""
                                                                                                                                     :labelFingerprint ""
                                                                                                                                     :name ""
                                                                                                                                     :projectId ""
                                                                                                                                     :resourceLabels {}
                                                                                                                                     :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 118

{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  labelFingerprint: '',
  name: '',
  projectId: '',
  resourceLabels: {},
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    labelFingerprint: '',
    name: '',
    projectId: '',
    resourceLabels: {},
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","labelFingerprint":"","name":"","projectId":"","resourceLabels":{},"zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "labelFingerprint": "",\n  "name": "",\n  "projectId": "",\n  "resourceLabels": {},\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels',
  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({
  clusterId: '',
  labelFingerprint: '',
  name: '',
  projectId: '',
  resourceLabels: {},
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    labelFingerprint: '',
    name: '',
    projectId: '',
    resourceLabels: {},
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  labelFingerprint: '',
  name: '',
  projectId: '',
  resourceLabels: {},
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    labelFingerprint: '',
    name: '',
    projectId: '',
    resourceLabels: {},
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","labelFingerprint":"","name":"","projectId":"","resourceLabels":{},"zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"labelFingerprint": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"resourceLabels": @{  },
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels",
  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([
    'clusterId' => '',
    'labelFingerprint' => '',
    'name' => '',
    'projectId' => '',
    'resourceLabels' => [
        
    ],
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels', [
  'body' => '{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'labelFingerprint' => '',
  'name' => '',
  'projectId' => '',
  'resourceLabels' => [
    
  ],
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'labelFingerprint' => '',
  'name' => '',
  'projectId' => '',
  'resourceLabels' => [
    
  ],
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels"

payload = {
    "clusterId": "",
    "labelFingerprint": "",
    "name": "",
    "projectId": "",
    "resourceLabels": {},
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels"

payload <- "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels")

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  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"labelFingerprint\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"resourceLabels\": {},\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels";

    let payload = json!({
        "clusterId": "",
        "labelFingerprint": "",
        "name": "",
        "projectId": "",
        "resourceLabels": json!({}),
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}'
echo '{
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": {},
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "labelFingerprint": "",\n  "name": "",\n  "projectId": "",\n  "resourceLabels": {},\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "labelFingerprint": "",
  "name": "",
  "projectId": "",
  "resourceLabels": [],
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId/resourceLabels")! 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 container.projects.zones.clusters.setMaintenancePolicy
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy");

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  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy" {:content-type :json
                                                                                                                             :form-params {:clusterId ""
                                                                                                                                           :maintenancePolicy {:resourceVersion ""
                                                                                                                                                               :window {:dailyMaintenanceWindow {:duration ""
                                                                                                                                                                                                 :startTime ""}
                                                                                                                                                                        :maintenanceExclusions {}
                                                                                                                                                                        :recurringWindow {:recurrence ""
                                                                                                                                                                                          :window {:endTime ""
                                                                                                                                                                                                   :maintenanceExclusionOptions {:scope ""}
                                                                                                                                                                                                   :startTime ""}}}}
                                                                                                                                           :name ""
                                                                                                                                           :projectId ""
                                                                                                                                           :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 495

{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  maintenancePolicy: {
    resourceVersion: '',
    window: {
      dailyMaintenanceWindow: {
        duration: '',
        startTime: ''
      },
      maintenanceExclusions: {},
      recurringWindow: {
        recurrence: '',
        window: {
          endTime: '',
          maintenanceExclusionOptions: {
            scope: ''
          },
          startTime: ''
        }
      }
    }
  },
  name: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {duration: '', startTime: ''},
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
        }
      }
    },
    name: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","maintenancePolicy":{"resourceVersion":"","window":{"dailyMaintenanceWindow":{"duration":"","startTime":""},"maintenanceExclusions":{},"recurringWindow":{"recurrence":"","window":{"endTime":"","maintenanceExclusionOptions":{"scope":""},"startTime":""}}}},"name":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "maintenancePolicy": {\n    "resourceVersion": "",\n    "window": {\n      "dailyMaintenanceWindow": {\n        "duration": "",\n        "startTime": ""\n      },\n      "maintenanceExclusions": {},\n      "recurringWindow": {\n        "recurrence": "",\n        "window": {\n          "endTime": "",\n          "maintenanceExclusionOptions": {\n            "scope": ""\n          },\n          "startTime": ""\n        }\n      }\n    }\n  },\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy',
  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({
  clusterId: '',
  maintenancePolicy: {
    resourceVersion: '',
    window: {
      dailyMaintenanceWindow: {duration: '', startTime: ''},
      maintenanceExclusions: {},
      recurringWindow: {
        recurrence: '',
        window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
      }
    }
  },
  name: '',
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {duration: '', startTime: ''},
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
        }
      }
    },
    name: '',
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  maintenancePolicy: {
    resourceVersion: '',
    window: {
      dailyMaintenanceWindow: {
        duration: '',
        startTime: ''
      },
      maintenanceExclusions: {},
      recurringWindow: {
        recurrence: '',
        window: {
          endTime: '',
          maintenanceExclusionOptions: {
            scope: ''
          },
          startTime: ''
        }
      }
    }
  },
  name: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    maintenancePolicy: {
      resourceVersion: '',
      window: {
        dailyMaintenanceWindow: {duration: '', startTime: ''},
        maintenanceExclusions: {},
        recurringWindow: {
          recurrence: '',
          window: {endTime: '', maintenanceExclusionOptions: {scope: ''}, startTime: ''}
        }
      }
    },
    name: '',
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","maintenancePolicy":{"resourceVersion":"","window":{"dailyMaintenanceWindow":{"duration":"","startTime":""},"maintenanceExclusions":{},"recurringWindow":{"recurrence":"","window":{"endTime":"","maintenanceExclusionOptions":{"scope":""},"startTime":""}}}},"name":"","projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"maintenancePolicy": @{ @"resourceVersion": @"", @"window": @{ @"dailyMaintenanceWindow": @{ @"duration": @"", @"startTime": @"" }, @"maintenanceExclusions": @{  }, @"recurringWindow": @{ @"recurrence": @"", @"window": @{ @"endTime": @"", @"maintenanceExclusionOptions": @{ @"scope": @"" }, @"startTime": @"" } } } },
                              @"name": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy",
  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([
    'clusterId' => '',
    'maintenancePolicy' => [
        'resourceVersion' => '',
        'window' => [
                'dailyMaintenanceWindow' => [
                                'duration' => '',
                                'startTime' => ''
                ],
                'maintenanceExclusions' => [
                                
                ],
                'recurringWindow' => [
                                'recurrence' => '',
                                'window' => [
                                                                'endTime' => '',
                                                                'maintenanceExclusionOptions' => [
                                                                                                                                'scope' => ''
                                                                ],
                                                                'startTime' => ''
                                ]
                ]
        ]
    ],
    'name' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy', [
  'body' => '{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'maintenancePolicy' => [
    'resourceVersion' => '',
    'window' => [
        'dailyMaintenanceWindow' => [
                'duration' => '',
                'startTime' => ''
        ],
        'maintenanceExclusions' => [
                
        ],
        'recurringWindow' => [
                'recurrence' => '',
                'window' => [
                                'endTime' => '',
                                'maintenanceExclusionOptions' => [
                                                                'scope' => ''
                                ],
                                'startTime' => ''
                ]
        ]
    ]
  ],
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'maintenancePolicy' => [
    'resourceVersion' => '',
    'window' => [
        'dailyMaintenanceWindow' => [
                'duration' => '',
                'startTime' => ''
        ],
        'maintenanceExclusions' => [
                
        ],
        'recurringWindow' => [
                'recurrence' => '',
                'window' => [
                                'endTime' => '',
                                'maintenanceExclusionOptions' => [
                                                                'scope' => ''
                                ],
                                'startTime' => ''
                ]
        ]
    ]
  ],
  'name' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy"

payload = {
    "clusterId": "",
    "maintenancePolicy": {
        "resourceVersion": "",
        "window": {
            "dailyMaintenanceWindow": {
                "duration": "",
                "startTime": ""
            },
            "maintenanceExclusions": {},
            "recurringWindow": {
                "recurrence": "",
                "window": {
                    "endTime": "",
                    "maintenanceExclusionOptions": { "scope": "" },
                    "startTime": ""
                }
            }
        }
    },
    "name": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy"

payload <- "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy")

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  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"maintenancePolicy\": {\n    \"resourceVersion\": \"\",\n    \"window\": {\n      \"dailyMaintenanceWindow\": {\n        \"duration\": \"\",\n        \"startTime\": \"\"\n      },\n      \"maintenanceExclusions\": {},\n      \"recurringWindow\": {\n        \"recurrence\": \"\",\n        \"window\": {\n          \"endTime\": \"\",\n          \"maintenanceExclusionOptions\": {\n            \"scope\": \"\"\n          },\n          \"startTime\": \"\"\n        }\n      }\n    }\n  },\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy";

    let payload = json!({
        "clusterId": "",
        "maintenancePolicy": json!({
            "resourceVersion": "",
            "window": json!({
                "dailyMaintenanceWindow": json!({
                    "duration": "",
                    "startTime": ""
                }),
                "maintenanceExclusions": json!({}),
                "recurringWindow": json!({
                    "recurrence": "",
                    "window": json!({
                        "endTime": "",
                        "maintenanceExclusionOptions": json!({"scope": ""}),
                        "startTime": ""
                    })
                })
            })
        }),
        "name": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "maintenancePolicy": {
    "resourceVersion": "",
    "window": {
      "dailyMaintenanceWindow": {
        "duration": "",
        "startTime": ""
      },
      "maintenanceExclusions": {},
      "recurringWindow": {
        "recurrence": "",
        "window": {
          "endTime": "",
          "maintenanceExclusionOptions": {
            "scope": ""
          },
          "startTime": ""
        }
      }
    }
  },
  "name": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "maintenancePolicy": {\n    "resourceVersion": "",\n    "window": {\n      "dailyMaintenanceWindow": {\n        "duration": "",\n        "startTime": ""\n      },\n      "maintenanceExclusions": {},\n      "recurringWindow": {\n        "recurrence": "",\n        "window": {\n          "endTime": "",\n          "maintenanceExclusionOptions": {\n            "scope": ""\n          },\n          "startTime": ""\n        }\n      }\n    }\n  },\n  "name": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "maintenancePolicy": [
    "resourceVersion": "",
    "window": [
      "dailyMaintenanceWindow": [
        "duration": "",
        "startTime": ""
      ],
      "maintenanceExclusions": [],
      "recurringWindow": [
        "recurrence": "",
        "window": [
          "endTime": "",
          "maintenanceExclusionOptions": ["scope": ""],
          "startTime": ""
        ]
      ]
    ]
  ],
  "name": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMaintenancePolicy")! 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 container.projects.zones.clusters.setMasterAuth
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth");

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  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth" {:content-type :json
                                                                                                                      :form-params {:action ""
                                                                                                                                    :clusterId ""
                                                                                                                                    :name ""
                                                                                                                                    :projectId ""
                                                                                                                                    :update {:clientCertificate ""
                                                                                                                                             :clientCertificateConfig {:issueClientCertificate false}
                                                                                                                                             :clientKey ""
                                                                                                                                             :clusterCaCertificate ""
                                                                                                                                             :password ""
                                                                                                                                             :username ""}
                                                                                                                                    :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth"),
    Content = new StringContent("{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth"

	payload := strings.NewReader("{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 302

{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth")
  .header("content-type", "application/json")
  .body("{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  action: '',
  clusterId: '',
  name: '',
  projectId: '',
  update: {
    clientCertificate: '',
    clientCertificateConfig: {
      issueClientCertificate: false
    },
    clientKey: '',
    clusterCaCertificate: '',
    password: '',
    username: ''
  },
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth',
  headers: {'content-type': 'application/json'},
  data: {
    action: '',
    clusterId: '',
    name: '',
    projectId: '',
    update: {
      clientCertificate: '',
      clientCertificateConfig: {issueClientCertificate: false},
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"action":"","clusterId":"","name":"","projectId":"","update":{"clientCertificate":"","clientCertificateConfig":{"issueClientCertificate":false},"clientKey":"","clusterCaCertificate":"","password":"","username":""},"zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "action": "",\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "update": {\n    "clientCertificate": "",\n    "clientCertificateConfig": {\n      "issueClientCertificate": false\n    },\n    "clientKey": "",\n    "clusterCaCertificate": "",\n    "password": "",\n    "username": ""\n  },\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth',
  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({
  action: '',
  clusterId: '',
  name: '',
  projectId: '',
  update: {
    clientCertificate: '',
    clientCertificateConfig: {issueClientCertificate: false},
    clientKey: '',
    clusterCaCertificate: '',
    password: '',
    username: ''
  },
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth',
  headers: {'content-type': 'application/json'},
  body: {
    action: '',
    clusterId: '',
    name: '',
    projectId: '',
    update: {
      clientCertificate: '',
      clientCertificateConfig: {issueClientCertificate: false},
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  action: '',
  clusterId: '',
  name: '',
  projectId: '',
  update: {
    clientCertificate: '',
    clientCertificateConfig: {
      issueClientCertificate: false
    },
    clientKey: '',
    clusterCaCertificate: '',
    password: '',
    username: ''
  },
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth',
  headers: {'content-type': 'application/json'},
  data: {
    action: '',
    clusterId: '',
    name: '',
    projectId: '',
    update: {
      clientCertificate: '',
      clientCertificateConfig: {issueClientCertificate: false},
      clientKey: '',
      clusterCaCertificate: '',
      password: '',
      username: ''
    },
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"action":"","clusterId":"","name":"","projectId":"","update":{"clientCertificate":"","clientCertificateConfig":{"issueClientCertificate":false},"clientKey":"","clusterCaCertificate":"","password":"","username":""},"zone":""}'
};

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 = @{ @"action": @"",
                              @"clusterId": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"update": @{ @"clientCertificate": @"", @"clientCertificateConfig": @{ @"issueClientCertificate": @NO }, @"clientKey": @"", @"clusterCaCertificate": @"", @"password": @"", @"username": @"" },
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth",
  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([
    'action' => '',
    'clusterId' => '',
    'name' => '',
    'projectId' => '',
    'update' => [
        'clientCertificate' => '',
        'clientCertificateConfig' => [
                'issueClientCertificate' => null
        ],
        'clientKey' => '',
        'clusterCaCertificate' => '',
        'password' => '',
        'username' => ''
    ],
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth', [
  'body' => '{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'action' => '',
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'update' => [
    'clientCertificate' => '',
    'clientCertificateConfig' => [
        'issueClientCertificate' => null
    ],
    'clientKey' => '',
    'clusterCaCertificate' => '',
    'password' => '',
    'username' => ''
  ],
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'action' => '',
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'update' => [
    'clientCertificate' => '',
    'clientCertificateConfig' => [
        'issueClientCertificate' => null
    ],
    'clientKey' => '',
    'clusterCaCertificate' => '',
    'password' => '',
    'username' => ''
  ],
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth"

payload = {
    "action": "",
    "clusterId": "",
    "name": "",
    "projectId": "",
    "update": {
        "clientCertificate": "",
        "clientCertificateConfig": { "issueClientCertificate": False },
        "clientKey": "",
        "clusterCaCertificate": "",
        "password": "",
        "username": ""
    },
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth"

payload <- "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth")

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  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth') do |req|
  req.body = "{\n  \"action\": \"\",\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"clientCertificate\": \"\",\n    \"clientCertificateConfig\": {\n      \"issueClientCertificate\": false\n    },\n    \"clientKey\": \"\",\n    \"clusterCaCertificate\": \"\",\n    \"password\": \"\",\n    \"username\": \"\"\n  },\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth";

    let payload = json!({
        "action": "",
        "clusterId": "",
        "name": "",
        "projectId": "",
        "update": json!({
            "clientCertificate": "",
            "clientCertificateConfig": json!({"issueClientCertificate": false}),
            "clientKey": "",
            "clusterCaCertificate": "",
            "password": "",
            "username": ""
        }),
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth \
  --header 'content-type: application/json' \
  --data '{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}'
echo '{
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "clientCertificate": "",
    "clientCertificateConfig": {
      "issueClientCertificate": false
    },
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  },
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "action": "",\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "update": {\n    "clientCertificate": "",\n    "clientCertificateConfig": {\n      "issueClientCertificate": false\n    },\n    "clientKey": "",\n    "clusterCaCertificate": "",\n    "password": "",\n    "username": ""\n  },\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "action": "",
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": [
    "clientCertificate": "",
    "clientCertificateConfig": ["issueClientCertificate": false],
    "clientKey": "",
    "clusterCaCertificate": "",
    "password": "",
    "username": ""
  ],
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setMasterAuth")! 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 container.projects.zones.clusters.setNetworkPolicy
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy");

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy" {:content-type :json
                                                                                                                         :form-params {:clusterId ""
                                                                                                                                       :name ""
                                                                                                                                       :networkPolicy {:enabled false
                                                                                                                                                       :provider ""}
                                                                                                                                       :projectId ""
                                                                                                                                       :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 135

{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  name: '',
  networkPolicy: {
    enabled: false,
    provider: ''
  },
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    name: '',
    networkPolicy: {enabled: false, provider: ''},
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","networkPolicy":{"enabled":false,"provider":""},"projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "name": "",\n  "networkPolicy": {\n    "enabled": false,\n    "provider": ""\n  },\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy',
  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({
  clusterId: '',
  name: '',
  networkPolicy: {enabled: false, provider: ''},
  projectId: '',
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    name: '',
    networkPolicy: {enabled: false, provider: ''},
    projectId: '',
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  name: '',
  networkPolicy: {
    enabled: false,
    provider: ''
  },
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    name: '',
    networkPolicy: {enabled: false, provider: ''},
    projectId: '',
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","networkPolicy":{"enabled":false,"provider":""},"projectId":"","zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"name": @"",
                              @"networkPolicy": @{ @"enabled": @NO, @"provider": @"" },
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy",
  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([
    'clusterId' => '',
    'name' => '',
    'networkPolicy' => [
        'enabled' => null,
        'provider' => ''
    ],
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy', [
  'body' => '{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'name' => '',
  'networkPolicy' => [
    'enabled' => null,
    'provider' => ''
  ],
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'name' => '',
  'networkPolicy' => [
    'enabled' => null,
    'provider' => ''
  ],
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy"

payload = {
    "clusterId": "",
    "name": "",
    "networkPolicy": {
        "enabled": False,
        "provider": ""
    },
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy"

payload <- "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy")

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"networkPolicy\": {\n    \"enabled\": false,\n    \"provider\": \"\"\n  },\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy";

    let payload = json!({
        "clusterId": "",
        "name": "",
        "networkPolicy": json!({
            "enabled": false,
            "provider": ""
        }),
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}'
echo '{
  "clusterId": "",
  "name": "",
  "networkPolicy": {
    "enabled": false,
    "provider": ""
  },
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "name": "",\n  "networkPolicy": {\n    "enabled": false,\n    "provider": ""\n  },\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "name": "",
  "networkPolicy": [
    "enabled": false,
    "provider": ""
  ],
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:setNetworkPolicy")! 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 container.projects.zones.clusters.startIpRotation
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation");

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation" {:content-type :json
                                                                                                                        :form-params {:clusterId ""
                                                                                                                                      :name ""
                                                                                                                                      :projectId ""
                                                                                                                                      :rotateCredentials false
                                                                                                                                      :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 98

{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  name: '',
  projectId: '',
  rotateCredentials: false,
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', projectId: '', rotateCredentials: false, zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","projectId":"","rotateCredentials":false,"zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "rotateCredentials": false,\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation',
  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({clusterId: '', name: '', projectId: '', rotateCredentials: false, zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation',
  headers: {'content-type': 'application/json'},
  body: {clusterId: '', name: '', projectId: '', rotateCredentials: false, zone: ''},
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  name: '',
  projectId: '',
  rotateCredentials: false,
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation',
  headers: {'content-type': 'application/json'},
  data: {clusterId: '', name: '', projectId: '', rotateCredentials: false, zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","projectId":"","rotateCredentials":false,"zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"rotateCredentials": @NO,
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation",
  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([
    'clusterId' => '',
    'name' => '',
    'projectId' => '',
    'rotateCredentials' => null,
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation', [
  'body' => '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'rotateCredentials' => null,
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'rotateCredentials' => null,
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation"

payload = {
    "clusterId": "",
    "name": "",
    "projectId": "",
    "rotateCredentials": False,
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation"

payload <- "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation")

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"rotateCredentials\": false,\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation";

    let payload = json!({
        "clusterId": "",
        "name": "",
        "projectId": "",
        "rotateCredentials": false,
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}'
echo '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "rotateCredentials": false,\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "name": "",
  "projectId": "",
  "rotateCredentials": false,
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId:startIpRotation")! 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 container.projects.zones.clusters.update
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId
QUERY PARAMS

projectId
zone
clusterId
BODY json

{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "additionalPodRangesConfig": {
      "podRangeNames": []
    },
    "desiredAddonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "desiredAuthenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "desiredBinaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "desiredClusterAutoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "desiredClusterTelemetry": {
      "type": ""
    },
    "desiredCostManagementConfig": {
      "enabled": false
    },
    "desiredDatabaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "desiredDatapathProvider": "",
    "desiredDefaultSnatStatus": {
      "disabled": false
    },
    "desiredDnsConfig": {
      "clusterDns": "",
      "clusterDnsDomain": "",
      "clusterDnsScope": ""
    },
    "desiredEnablePrivateEndpoint": false,
    "desiredGatewayApiConfig": {
      "channel": ""
    },
    "desiredGcfsConfig": {
      "enabled": false
    },
    "desiredIdentityServiceConfig": {
      "enabled": false
    },
    "desiredImageType": "",
    "desiredIntraNodeVisibilityConfig": {
      "enabled": false
    },
    "desiredL4ilbSubsettingConfig": {
      "enabled": false
    },
    "desiredLocations": [],
    "desiredLoggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "desiredLoggingService": "",
    "desiredMaster": {},
    "desiredMasterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "desiredMasterVersion": "",
    "desiredMeshCertificates": {
      "enableCertificates": false
    },
    "desiredMonitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "desiredMonitoringService": "",
    "desiredNodePoolAutoConfigNetworkTags": {
      "tags": []
    },
    "desiredNodePoolAutoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "desiredNodePoolId": "",
    "desiredNodePoolLoggingConfig": {
      "variantConfig": {
        "variant": ""
      }
    },
    "desiredNodeVersion": "",
    "desiredNotificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "desiredPodSecurityPolicyConfig": {
      "enabled": false
    },
    "desiredPrivateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "desiredPrivateIpv6GoogleAccess": "",
    "desiredProtectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "desiredReleaseChannel": {
      "channel": ""
    },
    "desiredResourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "desiredServiceExternalIpsConfig": {
      "enabled": false
    },
    "desiredShieldedNodes": {
      "enabled": false
    },
    "desiredStackType": "",
    "desiredTpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "desiredVerticalPodAutoscaling": {
      "enabled": false
    },
    "desiredWorkloadAltsConfig": {
      "enableAlts": false
    },
    "desiredWorkloadCertificates": {
      "enableCertificates": false
    },
    "desiredWorkloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "etag": "",
    "removedAdditionalPodRangesConfig": {}
  },
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PUT");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId");

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/put "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId" {:content-type :json
                                                                                                       :form-params {:clusterId ""
                                                                                                                     :name ""
                                                                                                                     :projectId ""
                                                                                                                     :update {:additionalPodRangesConfig {:podRangeNames []}
                                                                                                                              :desiredAddonsConfig {:cloudRunConfig {:disabled false
                                                                                                                                                                     :loadBalancerType ""}
                                                                                                                                                    :configConnectorConfig {:enabled false}
                                                                                                                                                    :dnsCacheConfig {:enabled false}
                                                                                                                                                    :gcePersistentDiskCsiDriverConfig {:enabled false}
                                                                                                                                                    :gcpFilestoreCsiDriverConfig {:enabled false}
                                                                                                                                                    :gkeBackupAgentConfig {:enabled false}
                                                                                                                                                    :horizontalPodAutoscaling {:disabled false}
                                                                                                                                                    :httpLoadBalancing {:disabled false}
                                                                                                                                                    :istioConfig {:auth ""
                                                                                                                                                                  :disabled false}
                                                                                                                                                    :kalmConfig {:enabled false}
                                                                                                                                                    :kubernetesDashboard {:disabled false}
                                                                                                                                                    :networkPolicyConfig {:disabled false}}
                                                                                                                              :desiredAuthenticatorGroupsConfig {:enabled false
                                                                                                                                                                 :securityGroup ""}
                                                                                                                              :desiredBinaryAuthorization {:enabled false
                                                                                                                                                           :evaluationMode ""}
                                                                                                                              :desiredClusterAutoscaling {:autoprovisioningLocations []
                                                                                                                                                          :autoprovisioningNodePoolDefaults {:bootDiskKmsKey ""
                                                                                                                                                                                             :diskSizeGb 0
                                                                                                                                                                                             :diskType ""
                                                                                                                                                                                             :imageType ""
                                                                                                                                                                                             :management {:autoRepair false
                                                                                                                                                                                                          :autoUpgrade false
                                                                                                                                                                                                          :upgradeOptions {:autoUpgradeStartTime ""
                                                                                                                                                                                                                           :description ""}}
                                                                                                                                                                                             :minCpuPlatform ""
                                                                                                                                                                                             :oauthScopes []
                                                                                                                                                                                             :serviceAccount ""
                                                                                                                                                                                             :shieldedInstanceConfig {:enableIntegrityMonitoring false
                                                                                                                                                                                                                      :enableSecureBoot false}
                                                                                                                                                                                             :upgradeSettings {:blueGreenSettings {:nodePoolSoakDuration ""
                                                                                                                                                                                                                                   :standardRolloutPolicy {:batchNodeCount 0
                                                                                                                                                                                                                                                           :batchPercentage ""
                                                                                                                                                                                                                                                           :batchSoakDuration ""}}
                                                                                                                                                                                                               :maxSurge 0
                                                                                                                                                                                                               :maxUnavailable 0
                                                                                                                                                                                                               :strategy ""}}
                                                                                                                                                          :autoscalingProfile ""
                                                                                                                                                          :enableNodeAutoprovisioning false
                                                                                                                                                          :resourceLimits [{:maximum ""
                                                                                                                                                                            :minimum ""
                                                                                                                                                                            :resourceType ""}]}
                                                                                                                              :desiredClusterTelemetry {:type ""}
                                                                                                                              :desiredCostManagementConfig {:enabled false}
                                                                                                                              :desiredDatabaseEncryption {:keyName ""
                                                                                                                                                          :state ""}
                                                                                                                              :desiredDatapathProvider ""
                                                                                                                              :desiredDefaultSnatStatus {:disabled false}
                                                                                                                              :desiredDnsConfig {:clusterDns ""
                                                                                                                                                 :clusterDnsDomain ""
                                                                                                                                                 :clusterDnsScope ""}
                                                                                                                              :desiredEnablePrivateEndpoint false
                                                                                                                              :desiredGatewayApiConfig {:channel ""}
                                                                                                                              :desiredGcfsConfig {:enabled false}
                                                                                                                              :desiredIdentityServiceConfig {:enabled false}
                                                                                                                              :desiredImageType ""
                                                                                                                              :desiredIntraNodeVisibilityConfig {:enabled false}
                                                                                                                              :desiredL4ilbSubsettingConfig {:enabled false}
                                                                                                                              :desiredLocations []
                                                                                                                              :desiredLoggingConfig {:componentConfig {:enableComponents []}}
                                                                                                                              :desiredLoggingService ""
                                                                                                                              :desiredMaster {}
                                                                                                                              :desiredMasterAuthorizedNetworksConfig {:cidrBlocks [{:cidrBlock ""
                                                                                                                                                                                    :displayName ""}]
                                                                                                                                                                      :enabled false
                                                                                                                                                                      :gcpPublicCidrsAccessEnabled false}
                                                                                                                              :desiredMasterVersion ""
                                                                                                                              :desiredMeshCertificates {:enableCertificates false}
                                                                                                                              :desiredMonitoringConfig {:componentConfig {:enableComponents []}
                                                                                                                                                        :managedPrometheusConfig {:enabled false}}
                                                                                                                              :desiredMonitoringService ""
                                                                                                                              :desiredNodePoolAutoConfigNetworkTags {:tags []}
                                                                                                                              :desiredNodePoolAutoscaling {:autoprovisioned false
                                                                                                                                                           :enabled false
                                                                                                                                                           :locationPolicy ""
                                                                                                                                                           :maxNodeCount 0
                                                                                                                                                           :minNodeCount 0
                                                                                                                                                           :totalMaxNodeCount 0
                                                                                                                                                           :totalMinNodeCount 0}
                                                                                                                              :desiredNodePoolId ""
                                                                                                                              :desiredNodePoolLoggingConfig {:variantConfig {:variant ""}}
                                                                                                                              :desiredNodeVersion ""
                                                                                                                              :desiredNotificationConfig {:pubsub {:enabled false
                                                                                                                                                                   :filter {:eventType []}
                                                                                                                                                                   :topic ""}}
                                                                                                                              :desiredPodSecurityPolicyConfig {:enabled false}
                                                                                                                              :desiredPrivateClusterConfig {:enablePrivateEndpoint false
                                                                                                                                                            :enablePrivateNodes false
                                                                                                                                                            :masterGlobalAccessConfig {:enabled false}
                                                                                                                                                            :masterIpv4CidrBlock ""
                                                                                                                                                            :peeringName ""
                                                                                                                                                            :privateEndpoint ""
                                                                                                                                                            :privateEndpointSubnetwork ""
                                                                                                                                                            :publicEndpoint ""}
                                                                                                                              :desiredPrivateIpv6GoogleAccess ""
                                                                                                                              :desiredProtectConfig {:workloadConfig {:auditMode ""}
                                                                                                                                                     :workloadVulnerabilityMode ""}
                                                                                                                              :desiredReleaseChannel {:channel ""}
                                                                                                                              :desiredResourceUsageExportConfig {:bigqueryDestination {:datasetId ""}
                                                                                                                                                                 :consumptionMeteringConfig {:enabled false}
                                                                                                                                                                 :enableNetworkEgressMetering false}
                                                                                                                              :desiredServiceExternalIpsConfig {:enabled false}
                                                                                                                              :desiredShieldedNodes {:enabled false}
                                                                                                                              :desiredStackType ""
                                                                                                                              :desiredTpuConfig {:enabled false
                                                                                                                                                 :ipv4CidrBlock ""
                                                                                                                                                 :useServiceNetworking false}
                                                                                                                              :desiredVerticalPodAutoscaling {:enabled false}
                                                                                                                              :desiredWorkloadAltsConfig {:enableAlts false}
                                                                                                                              :desiredWorkloadCertificates {:enableCertificates false}
                                                                                                                              :desiredWorkloadIdentityConfig {:identityNamespace ""
                                                                                                                                                              :identityProvider ""
                                                                                                                                                              :workloadPool ""}
                                                                                                                              :etag ""
                                                                                                                              :removedAdditionalPodRangesConfig {}}
                                                                                                                     :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"),
    Content = new StringContent("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"

	payload := strings.NewReader("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 6203

{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "additionalPodRangesConfig": {
      "podRangeNames": []
    },
    "desiredAddonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "desiredAuthenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "desiredBinaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "desiredClusterAutoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "desiredClusterTelemetry": {
      "type": ""
    },
    "desiredCostManagementConfig": {
      "enabled": false
    },
    "desiredDatabaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "desiredDatapathProvider": "",
    "desiredDefaultSnatStatus": {
      "disabled": false
    },
    "desiredDnsConfig": {
      "clusterDns": "",
      "clusterDnsDomain": "",
      "clusterDnsScope": ""
    },
    "desiredEnablePrivateEndpoint": false,
    "desiredGatewayApiConfig": {
      "channel": ""
    },
    "desiredGcfsConfig": {
      "enabled": false
    },
    "desiredIdentityServiceConfig": {
      "enabled": false
    },
    "desiredImageType": "",
    "desiredIntraNodeVisibilityConfig": {
      "enabled": false
    },
    "desiredL4ilbSubsettingConfig": {
      "enabled": false
    },
    "desiredLocations": [],
    "desiredLoggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "desiredLoggingService": "",
    "desiredMaster": {},
    "desiredMasterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "desiredMasterVersion": "",
    "desiredMeshCertificates": {
      "enableCertificates": false
    },
    "desiredMonitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "desiredMonitoringService": "",
    "desiredNodePoolAutoConfigNetworkTags": {
      "tags": []
    },
    "desiredNodePoolAutoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "desiredNodePoolId": "",
    "desiredNodePoolLoggingConfig": {
      "variantConfig": {
        "variant": ""
      }
    },
    "desiredNodeVersion": "",
    "desiredNotificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "desiredPodSecurityPolicyConfig": {
      "enabled": false
    },
    "desiredPrivateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "desiredPrivateIpv6GoogleAccess": "",
    "desiredProtectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "desiredReleaseChannel": {
      "channel": ""
    },
    "desiredResourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "desiredServiceExternalIpsConfig": {
      "enabled": false
    },
    "desiredShieldedNodes": {
      "enabled": false
    },
    "desiredStackType": "",
    "desiredTpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "desiredVerticalPodAutoscaling": {
      "enabled": false
    },
    "desiredWorkloadAltsConfig": {
      "enableAlts": false
    },
    "desiredWorkloadCertificates": {
      "enableCertificates": false
    },
    "desiredWorkloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "etag": "",
    "removedAdditionalPodRangesConfig": {}
  },
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .header("content-type", "application/json")
  .body("{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  clusterId: '',
  name: '',
  projectId: '',
  update: {
    additionalPodRangesConfig: {
      podRangeNames: []
    },
    desiredAddonsConfig: {
      cloudRunConfig: {
        disabled: false,
        loadBalancerType: ''
      },
      configConnectorConfig: {
        enabled: false
      },
      dnsCacheConfig: {
        enabled: false
      },
      gcePersistentDiskCsiDriverConfig: {
        enabled: false
      },
      gcpFilestoreCsiDriverConfig: {
        enabled: false
      },
      gkeBackupAgentConfig: {
        enabled: false
      },
      horizontalPodAutoscaling: {
        disabled: false
      },
      httpLoadBalancing: {
        disabled: false
      },
      istioConfig: {
        auth: '',
        disabled: false
      },
      kalmConfig: {
        enabled: false
      },
      kubernetesDashboard: {
        disabled: false
      },
      networkPolicyConfig: {
        disabled: false
      }
    },
    desiredAuthenticatorGroupsConfig: {
      enabled: false,
      securityGroup: ''
    },
    desiredBinaryAuthorization: {
      enabled: false,
      evaluationMode: ''
    },
    desiredClusterAutoscaling: {
      autoprovisioningLocations: [],
      autoprovisioningNodePoolDefaults: {
        bootDiskKmsKey: '',
        diskSizeGb: 0,
        diskType: '',
        imageType: '',
        management: {
          autoRepair: false,
          autoUpgrade: false,
          upgradeOptions: {
            autoUpgradeStartTime: '',
            description: ''
          }
        },
        minCpuPlatform: '',
        oauthScopes: [],
        serviceAccount: '',
        shieldedInstanceConfig: {
          enableIntegrityMonitoring: false,
          enableSecureBoot: false
        },
        upgradeSettings: {
          blueGreenSettings: {
            nodePoolSoakDuration: '',
            standardRolloutPolicy: {
              batchNodeCount: 0,
              batchPercentage: '',
              batchSoakDuration: ''
            }
          },
          maxSurge: 0,
          maxUnavailable: 0,
          strategy: ''
        }
      },
      autoscalingProfile: '',
      enableNodeAutoprovisioning: false,
      resourceLimits: [
        {
          maximum: '',
          minimum: '',
          resourceType: ''
        }
      ]
    },
    desiredClusterTelemetry: {
      type: ''
    },
    desiredCostManagementConfig: {
      enabled: false
    },
    desiredDatabaseEncryption: {
      keyName: '',
      state: ''
    },
    desiredDatapathProvider: '',
    desiredDefaultSnatStatus: {
      disabled: false
    },
    desiredDnsConfig: {
      clusterDns: '',
      clusterDnsDomain: '',
      clusterDnsScope: ''
    },
    desiredEnablePrivateEndpoint: false,
    desiredGatewayApiConfig: {
      channel: ''
    },
    desiredGcfsConfig: {
      enabled: false
    },
    desiredIdentityServiceConfig: {
      enabled: false
    },
    desiredImageType: '',
    desiredIntraNodeVisibilityConfig: {
      enabled: false
    },
    desiredL4ilbSubsettingConfig: {
      enabled: false
    },
    desiredLocations: [],
    desiredLoggingConfig: {
      componentConfig: {
        enableComponents: []
      }
    },
    desiredLoggingService: '',
    desiredMaster: {},
    desiredMasterAuthorizedNetworksConfig: {
      cidrBlocks: [
        {
          cidrBlock: '',
          displayName: ''
        }
      ],
      enabled: false,
      gcpPublicCidrsAccessEnabled: false
    },
    desiredMasterVersion: '',
    desiredMeshCertificates: {
      enableCertificates: false
    },
    desiredMonitoringConfig: {
      componentConfig: {
        enableComponents: []
      },
      managedPrometheusConfig: {
        enabled: false
      }
    },
    desiredMonitoringService: '',
    desiredNodePoolAutoConfigNetworkTags: {
      tags: []
    },
    desiredNodePoolAutoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    desiredNodePoolId: '',
    desiredNodePoolLoggingConfig: {
      variantConfig: {
        variant: ''
      }
    },
    desiredNodeVersion: '',
    desiredNotificationConfig: {
      pubsub: {
        enabled: false,
        filter: {
          eventType: []
        },
        topic: ''
      }
    },
    desiredPodSecurityPolicyConfig: {
      enabled: false
    },
    desiredPrivateClusterConfig: {
      enablePrivateEndpoint: false,
      enablePrivateNodes: false,
      masterGlobalAccessConfig: {
        enabled: false
      },
      masterIpv4CidrBlock: '',
      peeringName: '',
      privateEndpoint: '',
      privateEndpointSubnetwork: '',
      publicEndpoint: ''
    },
    desiredPrivateIpv6GoogleAccess: '',
    desiredProtectConfig: {
      workloadConfig: {
        auditMode: ''
      },
      workloadVulnerabilityMode: ''
    },
    desiredReleaseChannel: {
      channel: ''
    },
    desiredResourceUsageExportConfig: {
      bigqueryDestination: {
        datasetId: ''
      },
      consumptionMeteringConfig: {
        enabled: false
      },
      enableNetworkEgressMetering: false
    },
    desiredServiceExternalIpsConfig: {
      enabled: false
    },
    desiredShieldedNodes: {
      enabled: false
    },
    desiredStackType: '',
    desiredTpuConfig: {
      enabled: false,
      ipv4CidrBlock: '',
      useServiceNetworking: false
    },
    desiredVerticalPodAutoscaling: {
      enabled: false
    },
    desiredWorkloadAltsConfig: {
      enableAlts: false
    },
    desiredWorkloadCertificates: {
      enableCertificates: false
    },
    desiredWorkloadIdentityConfig: {
      identityNamespace: '',
      identityProvider: '',
      workloadPool: ''
    },
    etag: '',
    removedAdditionalPodRangesConfig: {}
  },
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PUT', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    name: '',
    projectId: '',
    update: {
      additionalPodRangesConfig: {podRangeNames: []},
      desiredAddonsConfig: {
        cloudRunConfig: {disabled: false, loadBalancerType: ''},
        configConnectorConfig: {enabled: false},
        dnsCacheConfig: {enabled: false},
        gcePersistentDiskCsiDriverConfig: {enabled: false},
        gcpFilestoreCsiDriverConfig: {enabled: false},
        gkeBackupAgentConfig: {enabled: false},
        horizontalPodAutoscaling: {disabled: false},
        httpLoadBalancing: {disabled: false},
        istioConfig: {auth: '', disabled: false},
        kalmConfig: {enabled: false},
        kubernetesDashboard: {disabled: false},
        networkPolicyConfig: {disabled: false}
      },
      desiredAuthenticatorGroupsConfig: {enabled: false, securityGroup: ''},
      desiredBinaryAuthorization: {enabled: false, evaluationMode: ''},
      desiredClusterAutoscaling: {
        autoprovisioningLocations: [],
        autoprovisioningNodePoolDefaults: {
          bootDiskKmsKey: '',
          diskSizeGb: 0,
          diskType: '',
          imageType: '',
          management: {
            autoRepair: false,
            autoUpgrade: false,
            upgradeOptions: {autoUpgradeStartTime: '', description: ''}
          },
          minCpuPlatform: '',
          oauthScopes: [],
          serviceAccount: '',
          shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
          upgradeSettings: {
            blueGreenSettings: {
              nodePoolSoakDuration: '',
              standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
            },
            maxSurge: 0,
            maxUnavailable: 0,
            strategy: ''
          }
        },
        autoscalingProfile: '',
        enableNodeAutoprovisioning: false,
        resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
      },
      desiredClusterTelemetry: {type: ''},
      desiredCostManagementConfig: {enabled: false},
      desiredDatabaseEncryption: {keyName: '', state: ''},
      desiredDatapathProvider: '',
      desiredDefaultSnatStatus: {disabled: false},
      desiredDnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
      desiredEnablePrivateEndpoint: false,
      desiredGatewayApiConfig: {channel: ''},
      desiredGcfsConfig: {enabled: false},
      desiredIdentityServiceConfig: {enabled: false},
      desiredImageType: '',
      desiredIntraNodeVisibilityConfig: {enabled: false},
      desiredL4ilbSubsettingConfig: {enabled: false},
      desiredLocations: [],
      desiredLoggingConfig: {componentConfig: {enableComponents: []}},
      desiredLoggingService: '',
      desiredMaster: {},
      desiredMasterAuthorizedNetworksConfig: {
        cidrBlocks: [{cidrBlock: '', displayName: ''}],
        enabled: false,
        gcpPublicCidrsAccessEnabled: false
      },
      desiredMasterVersion: '',
      desiredMeshCertificates: {enableCertificates: false},
      desiredMonitoringConfig: {
        componentConfig: {enableComponents: []},
        managedPrometheusConfig: {enabled: false}
      },
      desiredMonitoringService: '',
      desiredNodePoolAutoConfigNetworkTags: {tags: []},
      desiredNodePoolAutoscaling: {
        autoprovisioned: false,
        enabled: false,
        locationPolicy: '',
        maxNodeCount: 0,
        minNodeCount: 0,
        totalMaxNodeCount: 0,
        totalMinNodeCount: 0
      },
      desiredNodePoolId: '',
      desiredNodePoolLoggingConfig: {variantConfig: {variant: ''}},
      desiredNodeVersion: '',
      desiredNotificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
      desiredPodSecurityPolicyConfig: {enabled: false},
      desiredPrivateClusterConfig: {
        enablePrivateEndpoint: false,
        enablePrivateNodes: false,
        masterGlobalAccessConfig: {enabled: false},
        masterIpv4CidrBlock: '',
        peeringName: '',
        privateEndpoint: '',
        privateEndpointSubnetwork: '',
        publicEndpoint: ''
      },
      desiredPrivateIpv6GoogleAccess: '',
      desiredProtectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
      desiredReleaseChannel: {channel: ''},
      desiredResourceUsageExportConfig: {
        bigqueryDestination: {datasetId: ''},
        consumptionMeteringConfig: {enabled: false},
        enableNetworkEgressMetering: false
      },
      desiredServiceExternalIpsConfig: {enabled: false},
      desiredShieldedNodes: {enabled: false},
      desiredStackType: '',
      desiredTpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
      desiredVerticalPodAutoscaling: {enabled: false},
      desiredWorkloadAltsConfig: {enableAlts: false},
      desiredWorkloadCertificates: {enableCertificates: false},
      desiredWorkloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
      etag: '',
      removedAdditionalPodRangesConfig: {}
    },
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","projectId":"","update":{"additionalPodRangesConfig":{"podRangeNames":[]},"desiredAddonsConfig":{"cloudRunConfig":{"disabled":false,"loadBalancerType":""},"configConnectorConfig":{"enabled":false},"dnsCacheConfig":{"enabled":false},"gcePersistentDiskCsiDriverConfig":{"enabled":false},"gcpFilestoreCsiDriverConfig":{"enabled":false},"gkeBackupAgentConfig":{"enabled":false},"horizontalPodAutoscaling":{"disabled":false},"httpLoadBalancing":{"disabled":false},"istioConfig":{"auth":"","disabled":false},"kalmConfig":{"enabled":false},"kubernetesDashboard":{"disabled":false},"networkPolicyConfig":{"disabled":false}},"desiredAuthenticatorGroupsConfig":{"enabled":false,"securityGroup":""},"desiredBinaryAuthorization":{"enabled":false,"evaluationMode":""},"desiredClusterAutoscaling":{"autoprovisioningLocations":[],"autoprovisioningNodePoolDefaults":{"bootDiskKmsKey":"","diskSizeGb":0,"diskType":"","imageType":"","management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"minCpuPlatform":"","oauthScopes":[],"serviceAccount":"","shieldedInstanceConfig":{"enableIntegrityMonitoring":false,"enableSecureBoot":false},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""}},"autoscalingProfile":"","enableNodeAutoprovisioning":false,"resourceLimits":[{"maximum":"","minimum":"","resourceType":""}]},"desiredClusterTelemetry":{"type":""},"desiredCostManagementConfig":{"enabled":false},"desiredDatabaseEncryption":{"keyName":"","state":""},"desiredDatapathProvider":"","desiredDefaultSnatStatus":{"disabled":false},"desiredDnsConfig":{"clusterDns":"","clusterDnsDomain":"","clusterDnsScope":""},"desiredEnablePrivateEndpoint":false,"desiredGatewayApiConfig":{"channel":""},"desiredGcfsConfig":{"enabled":false},"desiredIdentityServiceConfig":{"enabled":false},"desiredImageType":"","desiredIntraNodeVisibilityConfig":{"enabled":false},"desiredL4ilbSubsettingConfig":{"enabled":false},"desiredLocations":[],"desiredLoggingConfig":{"componentConfig":{"enableComponents":[]}},"desiredLoggingService":"","desiredMaster":{},"desiredMasterAuthorizedNetworksConfig":{"cidrBlocks":[{"cidrBlock":"","displayName":""}],"enabled":false,"gcpPublicCidrsAccessEnabled":false},"desiredMasterVersion":"","desiredMeshCertificates":{"enableCertificates":false},"desiredMonitoringConfig":{"componentConfig":{"enableComponents":[]},"managedPrometheusConfig":{"enabled":false}},"desiredMonitoringService":"","desiredNodePoolAutoConfigNetworkTags":{"tags":[]},"desiredNodePoolAutoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"desiredNodePoolId":"","desiredNodePoolLoggingConfig":{"variantConfig":{"variant":""}},"desiredNodeVersion":"","desiredNotificationConfig":{"pubsub":{"enabled":false,"filter":{"eventType":[]},"topic":""}},"desiredPodSecurityPolicyConfig":{"enabled":false},"desiredPrivateClusterConfig":{"enablePrivateEndpoint":false,"enablePrivateNodes":false,"masterGlobalAccessConfig":{"enabled":false},"masterIpv4CidrBlock":"","peeringName":"","privateEndpoint":"","privateEndpointSubnetwork":"","publicEndpoint":""},"desiredPrivateIpv6GoogleAccess":"","desiredProtectConfig":{"workloadConfig":{"auditMode":""},"workloadVulnerabilityMode":""},"desiredReleaseChannel":{"channel":""},"desiredResourceUsageExportConfig":{"bigqueryDestination":{"datasetId":""},"consumptionMeteringConfig":{"enabled":false},"enableNetworkEgressMetering":false},"desiredServiceExternalIpsConfig":{"enabled":false},"desiredShieldedNodes":{"enabled":false},"desiredStackType":"","desiredTpuConfig":{"enabled":false,"ipv4CidrBlock":"","useServiceNetworking":false},"desiredVerticalPodAutoscaling":{"enabled":false},"desiredWorkloadAltsConfig":{"enableAlts":false},"desiredWorkloadCertificates":{"enableCertificates":false},"desiredWorkloadIdentityConfig":{"identityNamespace":"","identityProvider":"","workloadPool":""},"etag":"","removedAdditionalPodRangesConfig":{}},"zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "update": {\n    "additionalPodRangesConfig": {\n      "podRangeNames": []\n    },\n    "desiredAddonsConfig": {\n      "cloudRunConfig": {\n        "disabled": false,\n        "loadBalancerType": ""\n      },\n      "configConnectorConfig": {\n        "enabled": false\n      },\n      "dnsCacheConfig": {\n        "enabled": false\n      },\n      "gcePersistentDiskCsiDriverConfig": {\n        "enabled": false\n      },\n      "gcpFilestoreCsiDriverConfig": {\n        "enabled": false\n      },\n      "gkeBackupAgentConfig": {\n        "enabled": false\n      },\n      "horizontalPodAutoscaling": {\n        "disabled": false\n      },\n      "httpLoadBalancing": {\n        "disabled": false\n      },\n      "istioConfig": {\n        "auth": "",\n        "disabled": false\n      },\n      "kalmConfig": {\n        "enabled": false\n      },\n      "kubernetesDashboard": {\n        "disabled": false\n      },\n      "networkPolicyConfig": {\n        "disabled": false\n      }\n    },\n    "desiredAuthenticatorGroupsConfig": {\n      "enabled": false,\n      "securityGroup": ""\n    },\n    "desiredBinaryAuthorization": {\n      "enabled": false,\n      "evaluationMode": ""\n    },\n    "desiredClusterAutoscaling": {\n      "autoprovisioningLocations": [],\n      "autoprovisioningNodePoolDefaults": {\n        "bootDiskKmsKey": "",\n        "diskSizeGb": 0,\n        "diskType": "",\n        "imageType": "",\n        "management": {\n          "autoRepair": false,\n          "autoUpgrade": false,\n          "upgradeOptions": {\n            "autoUpgradeStartTime": "",\n            "description": ""\n          }\n        },\n        "minCpuPlatform": "",\n        "oauthScopes": [],\n        "serviceAccount": "",\n        "shieldedInstanceConfig": {\n          "enableIntegrityMonitoring": false,\n          "enableSecureBoot": false\n        },\n        "upgradeSettings": {\n          "blueGreenSettings": {\n            "nodePoolSoakDuration": "",\n            "standardRolloutPolicy": {\n              "batchNodeCount": 0,\n              "batchPercentage": "",\n              "batchSoakDuration": ""\n            }\n          },\n          "maxSurge": 0,\n          "maxUnavailable": 0,\n          "strategy": ""\n        }\n      },\n      "autoscalingProfile": "",\n      "enableNodeAutoprovisioning": false,\n      "resourceLimits": [\n        {\n          "maximum": "",\n          "minimum": "",\n          "resourceType": ""\n        }\n      ]\n    },\n    "desiredClusterTelemetry": {\n      "type": ""\n    },\n    "desiredCostManagementConfig": {\n      "enabled": false\n    },\n    "desiredDatabaseEncryption": {\n      "keyName": "",\n      "state": ""\n    },\n    "desiredDatapathProvider": "",\n    "desiredDefaultSnatStatus": {\n      "disabled": false\n    },\n    "desiredDnsConfig": {\n      "clusterDns": "",\n      "clusterDnsDomain": "",\n      "clusterDnsScope": ""\n    },\n    "desiredEnablePrivateEndpoint": false,\n    "desiredGatewayApiConfig": {\n      "channel": ""\n    },\n    "desiredGcfsConfig": {\n      "enabled": false\n    },\n    "desiredIdentityServiceConfig": {\n      "enabled": false\n    },\n    "desiredImageType": "",\n    "desiredIntraNodeVisibilityConfig": {\n      "enabled": false\n    },\n    "desiredL4ilbSubsettingConfig": {\n      "enabled": false\n    },\n    "desiredLocations": [],\n    "desiredLoggingConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      }\n    },\n    "desiredLoggingService": "",\n    "desiredMaster": {},\n    "desiredMasterAuthorizedNetworksConfig": {\n      "cidrBlocks": [\n        {\n          "cidrBlock": "",\n          "displayName": ""\n        }\n      ],\n      "enabled": false,\n      "gcpPublicCidrsAccessEnabled": false\n    },\n    "desiredMasterVersion": "",\n    "desiredMeshCertificates": {\n      "enableCertificates": false\n    },\n    "desiredMonitoringConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      },\n      "managedPrometheusConfig": {\n        "enabled": false\n      }\n    },\n    "desiredMonitoringService": "",\n    "desiredNodePoolAutoConfigNetworkTags": {\n      "tags": []\n    },\n    "desiredNodePoolAutoscaling": {\n      "autoprovisioned": false,\n      "enabled": false,\n      "locationPolicy": "",\n      "maxNodeCount": 0,\n      "minNodeCount": 0,\n      "totalMaxNodeCount": 0,\n      "totalMinNodeCount": 0\n    },\n    "desiredNodePoolId": "",\n    "desiredNodePoolLoggingConfig": {\n      "variantConfig": {\n        "variant": ""\n      }\n    },\n    "desiredNodeVersion": "",\n    "desiredNotificationConfig": {\n      "pubsub": {\n        "enabled": false,\n        "filter": {\n          "eventType": []\n        },\n        "topic": ""\n      }\n    },\n    "desiredPodSecurityPolicyConfig": {\n      "enabled": false\n    },\n    "desiredPrivateClusterConfig": {\n      "enablePrivateEndpoint": false,\n      "enablePrivateNodes": false,\n      "masterGlobalAccessConfig": {\n        "enabled": false\n      },\n      "masterIpv4CidrBlock": "",\n      "peeringName": "",\n      "privateEndpoint": "",\n      "privateEndpointSubnetwork": "",\n      "publicEndpoint": ""\n    },\n    "desiredPrivateIpv6GoogleAccess": "",\n    "desiredProtectConfig": {\n      "workloadConfig": {\n        "auditMode": ""\n      },\n      "workloadVulnerabilityMode": ""\n    },\n    "desiredReleaseChannel": {\n      "channel": ""\n    },\n    "desiredResourceUsageExportConfig": {\n      "bigqueryDestination": {\n        "datasetId": ""\n      },\n      "consumptionMeteringConfig": {\n        "enabled": false\n      },\n      "enableNetworkEgressMetering": false\n    },\n    "desiredServiceExternalIpsConfig": {\n      "enabled": false\n    },\n    "desiredShieldedNodes": {\n      "enabled": false\n    },\n    "desiredStackType": "",\n    "desiredTpuConfig": {\n      "enabled": false,\n      "ipv4CidrBlock": "",\n      "useServiceNetworking": false\n    },\n    "desiredVerticalPodAutoscaling": {\n      "enabled": false\n    },\n    "desiredWorkloadAltsConfig": {\n      "enableAlts": false\n    },\n    "desiredWorkloadCertificates": {\n      "enableCertificates": false\n    },\n    "desiredWorkloadIdentityConfig": {\n      "identityNamespace": "",\n      "identityProvider": "",\n      "workloadPool": ""\n    },\n    "etag": "",\n    "removedAdditionalPodRangesConfig": {}\n  },\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")
  .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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId',
  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({
  clusterId: '',
  name: '',
  projectId: '',
  update: {
    additionalPodRangesConfig: {podRangeNames: []},
    desiredAddonsConfig: {
      cloudRunConfig: {disabled: false, loadBalancerType: ''},
      configConnectorConfig: {enabled: false},
      dnsCacheConfig: {enabled: false},
      gcePersistentDiskCsiDriverConfig: {enabled: false},
      gcpFilestoreCsiDriverConfig: {enabled: false},
      gkeBackupAgentConfig: {enabled: false},
      horizontalPodAutoscaling: {disabled: false},
      httpLoadBalancing: {disabled: false},
      istioConfig: {auth: '', disabled: false},
      kalmConfig: {enabled: false},
      kubernetesDashboard: {disabled: false},
      networkPolicyConfig: {disabled: false}
    },
    desiredAuthenticatorGroupsConfig: {enabled: false, securityGroup: ''},
    desiredBinaryAuthorization: {enabled: false, evaluationMode: ''},
    desiredClusterAutoscaling: {
      autoprovisioningLocations: [],
      autoprovisioningNodePoolDefaults: {
        bootDiskKmsKey: '',
        diskSizeGb: 0,
        diskType: '',
        imageType: '',
        management: {
          autoRepair: false,
          autoUpgrade: false,
          upgradeOptions: {autoUpgradeStartTime: '', description: ''}
        },
        minCpuPlatform: '',
        oauthScopes: [],
        serviceAccount: '',
        shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
        upgradeSettings: {
          blueGreenSettings: {
            nodePoolSoakDuration: '',
            standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
          },
          maxSurge: 0,
          maxUnavailable: 0,
          strategy: ''
        }
      },
      autoscalingProfile: '',
      enableNodeAutoprovisioning: false,
      resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
    },
    desiredClusterTelemetry: {type: ''},
    desiredCostManagementConfig: {enabled: false},
    desiredDatabaseEncryption: {keyName: '', state: ''},
    desiredDatapathProvider: '',
    desiredDefaultSnatStatus: {disabled: false},
    desiredDnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
    desiredEnablePrivateEndpoint: false,
    desiredGatewayApiConfig: {channel: ''},
    desiredGcfsConfig: {enabled: false},
    desiredIdentityServiceConfig: {enabled: false},
    desiredImageType: '',
    desiredIntraNodeVisibilityConfig: {enabled: false},
    desiredL4ilbSubsettingConfig: {enabled: false},
    desiredLocations: [],
    desiredLoggingConfig: {componentConfig: {enableComponents: []}},
    desiredLoggingService: '',
    desiredMaster: {},
    desiredMasterAuthorizedNetworksConfig: {
      cidrBlocks: [{cidrBlock: '', displayName: ''}],
      enabled: false,
      gcpPublicCidrsAccessEnabled: false
    },
    desiredMasterVersion: '',
    desiredMeshCertificates: {enableCertificates: false},
    desiredMonitoringConfig: {
      componentConfig: {enableComponents: []},
      managedPrometheusConfig: {enabled: false}
    },
    desiredMonitoringService: '',
    desiredNodePoolAutoConfigNetworkTags: {tags: []},
    desiredNodePoolAutoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    desiredNodePoolId: '',
    desiredNodePoolLoggingConfig: {variantConfig: {variant: ''}},
    desiredNodeVersion: '',
    desiredNotificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
    desiredPodSecurityPolicyConfig: {enabled: false},
    desiredPrivateClusterConfig: {
      enablePrivateEndpoint: false,
      enablePrivateNodes: false,
      masterGlobalAccessConfig: {enabled: false},
      masterIpv4CidrBlock: '',
      peeringName: '',
      privateEndpoint: '',
      privateEndpointSubnetwork: '',
      publicEndpoint: ''
    },
    desiredPrivateIpv6GoogleAccess: '',
    desiredProtectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
    desiredReleaseChannel: {channel: ''},
    desiredResourceUsageExportConfig: {
      bigqueryDestination: {datasetId: ''},
      consumptionMeteringConfig: {enabled: false},
      enableNetworkEgressMetering: false
    },
    desiredServiceExternalIpsConfig: {enabled: false},
    desiredShieldedNodes: {enabled: false},
    desiredStackType: '',
    desiredTpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
    desiredVerticalPodAutoscaling: {enabled: false},
    desiredWorkloadAltsConfig: {enableAlts: false},
    desiredWorkloadCertificates: {enableCertificates: false},
    desiredWorkloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
    etag: '',
    removedAdditionalPodRangesConfig: {}
  },
  zone: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId',
  headers: {'content-type': 'application/json'},
  body: {
    clusterId: '',
    name: '',
    projectId: '',
    update: {
      additionalPodRangesConfig: {podRangeNames: []},
      desiredAddonsConfig: {
        cloudRunConfig: {disabled: false, loadBalancerType: ''},
        configConnectorConfig: {enabled: false},
        dnsCacheConfig: {enabled: false},
        gcePersistentDiskCsiDriverConfig: {enabled: false},
        gcpFilestoreCsiDriverConfig: {enabled: false},
        gkeBackupAgentConfig: {enabled: false},
        horizontalPodAutoscaling: {disabled: false},
        httpLoadBalancing: {disabled: false},
        istioConfig: {auth: '', disabled: false},
        kalmConfig: {enabled: false},
        kubernetesDashboard: {disabled: false},
        networkPolicyConfig: {disabled: false}
      },
      desiredAuthenticatorGroupsConfig: {enabled: false, securityGroup: ''},
      desiredBinaryAuthorization: {enabled: false, evaluationMode: ''},
      desiredClusterAutoscaling: {
        autoprovisioningLocations: [],
        autoprovisioningNodePoolDefaults: {
          bootDiskKmsKey: '',
          diskSizeGb: 0,
          diskType: '',
          imageType: '',
          management: {
            autoRepair: false,
            autoUpgrade: false,
            upgradeOptions: {autoUpgradeStartTime: '', description: ''}
          },
          minCpuPlatform: '',
          oauthScopes: [],
          serviceAccount: '',
          shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
          upgradeSettings: {
            blueGreenSettings: {
              nodePoolSoakDuration: '',
              standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
            },
            maxSurge: 0,
            maxUnavailable: 0,
            strategy: ''
          }
        },
        autoscalingProfile: '',
        enableNodeAutoprovisioning: false,
        resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
      },
      desiredClusterTelemetry: {type: ''},
      desiredCostManagementConfig: {enabled: false},
      desiredDatabaseEncryption: {keyName: '', state: ''},
      desiredDatapathProvider: '',
      desiredDefaultSnatStatus: {disabled: false},
      desiredDnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
      desiredEnablePrivateEndpoint: false,
      desiredGatewayApiConfig: {channel: ''},
      desiredGcfsConfig: {enabled: false},
      desiredIdentityServiceConfig: {enabled: false},
      desiredImageType: '',
      desiredIntraNodeVisibilityConfig: {enabled: false},
      desiredL4ilbSubsettingConfig: {enabled: false},
      desiredLocations: [],
      desiredLoggingConfig: {componentConfig: {enableComponents: []}},
      desiredLoggingService: '',
      desiredMaster: {},
      desiredMasterAuthorizedNetworksConfig: {
        cidrBlocks: [{cidrBlock: '', displayName: ''}],
        enabled: false,
        gcpPublicCidrsAccessEnabled: false
      },
      desiredMasterVersion: '',
      desiredMeshCertificates: {enableCertificates: false},
      desiredMonitoringConfig: {
        componentConfig: {enableComponents: []},
        managedPrometheusConfig: {enabled: false}
      },
      desiredMonitoringService: '',
      desiredNodePoolAutoConfigNetworkTags: {tags: []},
      desiredNodePoolAutoscaling: {
        autoprovisioned: false,
        enabled: false,
        locationPolicy: '',
        maxNodeCount: 0,
        minNodeCount: 0,
        totalMaxNodeCount: 0,
        totalMinNodeCount: 0
      },
      desiredNodePoolId: '',
      desiredNodePoolLoggingConfig: {variantConfig: {variant: ''}},
      desiredNodeVersion: '',
      desiredNotificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
      desiredPodSecurityPolicyConfig: {enabled: false},
      desiredPrivateClusterConfig: {
        enablePrivateEndpoint: false,
        enablePrivateNodes: false,
        masterGlobalAccessConfig: {enabled: false},
        masterIpv4CidrBlock: '',
        peeringName: '',
        privateEndpoint: '',
        privateEndpointSubnetwork: '',
        publicEndpoint: ''
      },
      desiredPrivateIpv6GoogleAccess: '',
      desiredProtectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
      desiredReleaseChannel: {channel: ''},
      desiredResourceUsageExportConfig: {
        bigqueryDestination: {datasetId: ''},
        consumptionMeteringConfig: {enabled: false},
        enableNetworkEgressMetering: false
      },
      desiredServiceExternalIpsConfig: {enabled: false},
      desiredShieldedNodes: {enabled: false},
      desiredStackType: '',
      desiredTpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
      desiredVerticalPodAutoscaling: {enabled: false},
      desiredWorkloadAltsConfig: {enableAlts: false},
      desiredWorkloadCertificates: {enableCertificates: false},
      desiredWorkloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
      etag: '',
      removedAdditionalPodRangesConfig: {}
    },
    zone: ''
  },
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  clusterId: '',
  name: '',
  projectId: '',
  update: {
    additionalPodRangesConfig: {
      podRangeNames: []
    },
    desiredAddonsConfig: {
      cloudRunConfig: {
        disabled: false,
        loadBalancerType: ''
      },
      configConnectorConfig: {
        enabled: false
      },
      dnsCacheConfig: {
        enabled: false
      },
      gcePersistentDiskCsiDriverConfig: {
        enabled: false
      },
      gcpFilestoreCsiDriverConfig: {
        enabled: false
      },
      gkeBackupAgentConfig: {
        enabled: false
      },
      horizontalPodAutoscaling: {
        disabled: false
      },
      httpLoadBalancing: {
        disabled: false
      },
      istioConfig: {
        auth: '',
        disabled: false
      },
      kalmConfig: {
        enabled: false
      },
      kubernetesDashboard: {
        disabled: false
      },
      networkPolicyConfig: {
        disabled: false
      }
    },
    desiredAuthenticatorGroupsConfig: {
      enabled: false,
      securityGroup: ''
    },
    desiredBinaryAuthorization: {
      enabled: false,
      evaluationMode: ''
    },
    desiredClusterAutoscaling: {
      autoprovisioningLocations: [],
      autoprovisioningNodePoolDefaults: {
        bootDiskKmsKey: '',
        diskSizeGb: 0,
        diskType: '',
        imageType: '',
        management: {
          autoRepair: false,
          autoUpgrade: false,
          upgradeOptions: {
            autoUpgradeStartTime: '',
            description: ''
          }
        },
        minCpuPlatform: '',
        oauthScopes: [],
        serviceAccount: '',
        shieldedInstanceConfig: {
          enableIntegrityMonitoring: false,
          enableSecureBoot: false
        },
        upgradeSettings: {
          blueGreenSettings: {
            nodePoolSoakDuration: '',
            standardRolloutPolicy: {
              batchNodeCount: 0,
              batchPercentage: '',
              batchSoakDuration: ''
            }
          },
          maxSurge: 0,
          maxUnavailable: 0,
          strategy: ''
        }
      },
      autoscalingProfile: '',
      enableNodeAutoprovisioning: false,
      resourceLimits: [
        {
          maximum: '',
          minimum: '',
          resourceType: ''
        }
      ]
    },
    desiredClusterTelemetry: {
      type: ''
    },
    desiredCostManagementConfig: {
      enabled: false
    },
    desiredDatabaseEncryption: {
      keyName: '',
      state: ''
    },
    desiredDatapathProvider: '',
    desiredDefaultSnatStatus: {
      disabled: false
    },
    desiredDnsConfig: {
      clusterDns: '',
      clusterDnsDomain: '',
      clusterDnsScope: ''
    },
    desiredEnablePrivateEndpoint: false,
    desiredGatewayApiConfig: {
      channel: ''
    },
    desiredGcfsConfig: {
      enabled: false
    },
    desiredIdentityServiceConfig: {
      enabled: false
    },
    desiredImageType: '',
    desiredIntraNodeVisibilityConfig: {
      enabled: false
    },
    desiredL4ilbSubsettingConfig: {
      enabled: false
    },
    desiredLocations: [],
    desiredLoggingConfig: {
      componentConfig: {
        enableComponents: []
      }
    },
    desiredLoggingService: '',
    desiredMaster: {},
    desiredMasterAuthorizedNetworksConfig: {
      cidrBlocks: [
        {
          cidrBlock: '',
          displayName: ''
        }
      ],
      enabled: false,
      gcpPublicCidrsAccessEnabled: false
    },
    desiredMasterVersion: '',
    desiredMeshCertificates: {
      enableCertificates: false
    },
    desiredMonitoringConfig: {
      componentConfig: {
        enableComponents: []
      },
      managedPrometheusConfig: {
        enabled: false
      }
    },
    desiredMonitoringService: '',
    desiredNodePoolAutoConfigNetworkTags: {
      tags: []
    },
    desiredNodePoolAutoscaling: {
      autoprovisioned: false,
      enabled: false,
      locationPolicy: '',
      maxNodeCount: 0,
      minNodeCount: 0,
      totalMaxNodeCount: 0,
      totalMinNodeCount: 0
    },
    desiredNodePoolId: '',
    desiredNodePoolLoggingConfig: {
      variantConfig: {
        variant: ''
      }
    },
    desiredNodeVersion: '',
    desiredNotificationConfig: {
      pubsub: {
        enabled: false,
        filter: {
          eventType: []
        },
        topic: ''
      }
    },
    desiredPodSecurityPolicyConfig: {
      enabled: false
    },
    desiredPrivateClusterConfig: {
      enablePrivateEndpoint: false,
      enablePrivateNodes: false,
      masterGlobalAccessConfig: {
        enabled: false
      },
      masterIpv4CidrBlock: '',
      peeringName: '',
      privateEndpoint: '',
      privateEndpointSubnetwork: '',
      publicEndpoint: ''
    },
    desiredPrivateIpv6GoogleAccess: '',
    desiredProtectConfig: {
      workloadConfig: {
        auditMode: ''
      },
      workloadVulnerabilityMode: ''
    },
    desiredReleaseChannel: {
      channel: ''
    },
    desiredResourceUsageExportConfig: {
      bigqueryDestination: {
        datasetId: ''
      },
      consumptionMeteringConfig: {
        enabled: false
      },
      enableNetworkEgressMetering: false
    },
    desiredServiceExternalIpsConfig: {
      enabled: false
    },
    desiredShieldedNodes: {
      enabled: false
    },
    desiredStackType: '',
    desiredTpuConfig: {
      enabled: false,
      ipv4CidrBlock: '',
      useServiceNetworking: false
    },
    desiredVerticalPodAutoscaling: {
      enabled: false
    },
    desiredWorkloadAltsConfig: {
      enableAlts: false
    },
    desiredWorkloadCertificates: {
      enableCertificates: false
    },
    desiredWorkloadIdentityConfig: {
      identityNamespace: '',
      identityProvider: '',
      workloadPool: ''
    },
    etag: '',
    removedAdditionalPodRangesConfig: {}
  },
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId',
  headers: {'content-type': 'application/json'},
  data: {
    clusterId: '',
    name: '',
    projectId: '',
    update: {
      additionalPodRangesConfig: {podRangeNames: []},
      desiredAddonsConfig: {
        cloudRunConfig: {disabled: false, loadBalancerType: ''},
        configConnectorConfig: {enabled: false},
        dnsCacheConfig: {enabled: false},
        gcePersistentDiskCsiDriverConfig: {enabled: false},
        gcpFilestoreCsiDriverConfig: {enabled: false},
        gkeBackupAgentConfig: {enabled: false},
        horizontalPodAutoscaling: {disabled: false},
        httpLoadBalancing: {disabled: false},
        istioConfig: {auth: '', disabled: false},
        kalmConfig: {enabled: false},
        kubernetesDashboard: {disabled: false},
        networkPolicyConfig: {disabled: false}
      },
      desiredAuthenticatorGroupsConfig: {enabled: false, securityGroup: ''},
      desiredBinaryAuthorization: {enabled: false, evaluationMode: ''},
      desiredClusterAutoscaling: {
        autoprovisioningLocations: [],
        autoprovisioningNodePoolDefaults: {
          bootDiskKmsKey: '',
          diskSizeGb: 0,
          diskType: '',
          imageType: '',
          management: {
            autoRepair: false,
            autoUpgrade: false,
            upgradeOptions: {autoUpgradeStartTime: '', description: ''}
          },
          minCpuPlatform: '',
          oauthScopes: [],
          serviceAccount: '',
          shieldedInstanceConfig: {enableIntegrityMonitoring: false, enableSecureBoot: false},
          upgradeSettings: {
            blueGreenSettings: {
              nodePoolSoakDuration: '',
              standardRolloutPolicy: {batchNodeCount: 0, batchPercentage: '', batchSoakDuration: ''}
            },
            maxSurge: 0,
            maxUnavailable: 0,
            strategy: ''
          }
        },
        autoscalingProfile: '',
        enableNodeAutoprovisioning: false,
        resourceLimits: [{maximum: '', minimum: '', resourceType: ''}]
      },
      desiredClusterTelemetry: {type: ''},
      desiredCostManagementConfig: {enabled: false},
      desiredDatabaseEncryption: {keyName: '', state: ''},
      desiredDatapathProvider: '',
      desiredDefaultSnatStatus: {disabled: false},
      desiredDnsConfig: {clusterDns: '', clusterDnsDomain: '', clusterDnsScope: ''},
      desiredEnablePrivateEndpoint: false,
      desiredGatewayApiConfig: {channel: ''},
      desiredGcfsConfig: {enabled: false},
      desiredIdentityServiceConfig: {enabled: false},
      desiredImageType: '',
      desiredIntraNodeVisibilityConfig: {enabled: false},
      desiredL4ilbSubsettingConfig: {enabled: false},
      desiredLocations: [],
      desiredLoggingConfig: {componentConfig: {enableComponents: []}},
      desiredLoggingService: '',
      desiredMaster: {},
      desiredMasterAuthorizedNetworksConfig: {
        cidrBlocks: [{cidrBlock: '', displayName: ''}],
        enabled: false,
        gcpPublicCidrsAccessEnabled: false
      },
      desiredMasterVersion: '',
      desiredMeshCertificates: {enableCertificates: false},
      desiredMonitoringConfig: {
        componentConfig: {enableComponents: []},
        managedPrometheusConfig: {enabled: false}
      },
      desiredMonitoringService: '',
      desiredNodePoolAutoConfigNetworkTags: {tags: []},
      desiredNodePoolAutoscaling: {
        autoprovisioned: false,
        enabled: false,
        locationPolicy: '',
        maxNodeCount: 0,
        minNodeCount: 0,
        totalMaxNodeCount: 0,
        totalMinNodeCount: 0
      },
      desiredNodePoolId: '',
      desiredNodePoolLoggingConfig: {variantConfig: {variant: ''}},
      desiredNodeVersion: '',
      desiredNotificationConfig: {pubsub: {enabled: false, filter: {eventType: []}, topic: ''}},
      desiredPodSecurityPolicyConfig: {enabled: false},
      desiredPrivateClusterConfig: {
        enablePrivateEndpoint: false,
        enablePrivateNodes: false,
        masterGlobalAccessConfig: {enabled: false},
        masterIpv4CidrBlock: '',
        peeringName: '',
        privateEndpoint: '',
        privateEndpointSubnetwork: '',
        publicEndpoint: ''
      },
      desiredPrivateIpv6GoogleAccess: '',
      desiredProtectConfig: {workloadConfig: {auditMode: ''}, workloadVulnerabilityMode: ''},
      desiredReleaseChannel: {channel: ''},
      desiredResourceUsageExportConfig: {
        bigqueryDestination: {datasetId: ''},
        consumptionMeteringConfig: {enabled: false},
        enableNetworkEgressMetering: false
      },
      desiredServiceExternalIpsConfig: {enabled: false},
      desiredShieldedNodes: {enabled: false},
      desiredStackType: '',
      desiredTpuConfig: {enabled: false, ipv4CidrBlock: '', useServiceNetworking: false},
      desiredVerticalPodAutoscaling: {enabled: false},
      desiredWorkloadAltsConfig: {enableAlts: false},
      desiredWorkloadCertificates: {enableCertificates: false},
      desiredWorkloadIdentityConfig: {identityNamespace: '', identityProvider: '', workloadPool: ''},
      etag: '',
      removedAdditionalPodRangesConfig: {}
    },
    zone: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"clusterId":"","name":"","projectId":"","update":{"additionalPodRangesConfig":{"podRangeNames":[]},"desiredAddonsConfig":{"cloudRunConfig":{"disabled":false,"loadBalancerType":""},"configConnectorConfig":{"enabled":false},"dnsCacheConfig":{"enabled":false},"gcePersistentDiskCsiDriverConfig":{"enabled":false},"gcpFilestoreCsiDriverConfig":{"enabled":false},"gkeBackupAgentConfig":{"enabled":false},"horizontalPodAutoscaling":{"disabled":false},"httpLoadBalancing":{"disabled":false},"istioConfig":{"auth":"","disabled":false},"kalmConfig":{"enabled":false},"kubernetesDashboard":{"disabled":false},"networkPolicyConfig":{"disabled":false}},"desiredAuthenticatorGroupsConfig":{"enabled":false,"securityGroup":""},"desiredBinaryAuthorization":{"enabled":false,"evaluationMode":""},"desiredClusterAutoscaling":{"autoprovisioningLocations":[],"autoprovisioningNodePoolDefaults":{"bootDiskKmsKey":"","diskSizeGb":0,"diskType":"","imageType":"","management":{"autoRepair":false,"autoUpgrade":false,"upgradeOptions":{"autoUpgradeStartTime":"","description":""}},"minCpuPlatform":"","oauthScopes":[],"serviceAccount":"","shieldedInstanceConfig":{"enableIntegrityMonitoring":false,"enableSecureBoot":false},"upgradeSettings":{"blueGreenSettings":{"nodePoolSoakDuration":"","standardRolloutPolicy":{"batchNodeCount":0,"batchPercentage":"","batchSoakDuration":""}},"maxSurge":0,"maxUnavailable":0,"strategy":""}},"autoscalingProfile":"","enableNodeAutoprovisioning":false,"resourceLimits":[{"maximum":"","minimum":"","resourceType":""}]},"desiredClusterTelemetry":{"type":""},"desiredCostManagementConfig":{"enabled":false},"desiredDatabaseEncryption":{"keyName":"","state":""},"desiredDatapathProvider":"","desiredDefaultSnatStatus":{"disabled":false},"desiredDnsConfig":{"clusterDns":"","clusterDnsDomain":"","clusterDnsScope":""},"desiredEnablePrivateEndpoint":false,"desiredGatewayApiConfig":{"channel":""},"desiredGcfsConfig":{"enabled":false},"desiredIdentityServiceConfig":{"enabled":false},"desiredImageType":"","desiredIntraNodeVisibilityConfig":{"enabled":false},"desiredL4ilbSubsettingConfig":{"enabled":false},"desiredLocations":[],"desiredLoggingConfig":{"componentConfig":{"enableComponents":[]}},"desiredLoggingService":"","desiredMaster":{},"desiredMasterAuthorizedNetworksConfig":{"cidrBlocks":[{"cidrBlock":"","displayName":""}],"enabled":false,"gcpPublicCidrsAccessEnabled":false},"desiredMasterVersion":"","desiredMeshCertificates":{"enableCertificates":false},"desiredMonitoringConfig":{"componentConfig":{"enableComponents":[]},"managedPrometheusConfig":{"enabled":false}},"desiredMonitoringService":"","desiredNodePoolAutoConfigNetworkTags":{"tags":[]},"desiredNodePoolAutoscaling":{"autoprovisioned":false,"enabled":false,"locationPolicy":"","maxNodeCount":0,"minNodeCount":0,"totalMaxNodeCount":0,"totalMinNodeCount":0},"desiredNodePoolId":"","desiredNodePoolLoggingConfig":{"variantConfig":{"variant":""}},"desiredNodeVersion":"","desiredNotificationConfig":{"pubsub":{"enabled":false,"filter":{"eventType":[]},"topic":""}},"desiredPodSecurityPolicyConfig":{"enabled":false},"desiredPrivateClusterConfig":{"enablePrivateEndpoint":false,"enablePrivateNodes":false,"masterGlobalAccessConfig":{"enabled":false},"masterIpv4CidrBlock":"","peeringName":"","privateEndpoint":"","privateEndpointSubnetwork":"","publicEndpoint":""},"desiredPrivateIpv6GoogleAccess":"","desiredProtectConfig":{"workloadConfig":{"auditMode":""},"workloadVulnerabilityMode":""},"desiredReleaseChannel":{"channel":""},"desiredResourceUsageExportConfig":{"bigqueryDestination":{"datasetId":""},"consumptionMeteringConfig":{"enabled":false},"enableNetworkEgressMetering":false},"desiredServiceExternalIpsConfig":{"enabled":false},"desiredShieldedNodes":{"enabled":false},"desiredStackType":"","desiredTpuConfig":{"enabled":false,"ipv4CidrBlock":"","useServiceNetworking":false},"desiredVerticalPodAutoscaling":{"enabled":false},"desiredWorkloadAltsConfig":{"enableAlts":false},"desiredWorkloadCertificates":{"enableCertificates":false},"desiredWorkloadIdentityConfig":{"identityNamespace":"","identityProvider":"","workloadPool":""},"etag":"","removedAdditionalPodRangesConfig":{}},"zone":""}'
};

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 = @{ @"clusterId": @"",
                              @"name": @"",
                              @"projectId": @"",
                              @"update": @{ @"additionalPodRangesConfig": @{ @"podRangeNames": @[  ] }, @"desiredAddonsConfig": @{ @"cloudRunConfig": @{ @"disabled": @NO, @"loadBalancerType": @"" }, @"configConnectorConfig": @{ @"enabled": @NO }, @"dnsCacheConfig": @{ @"enabled": @NO }, @"gcePersistentDiskCsiDriverConfig": @{ @"enabled": @NO }, @"gcpFilestoreCsiDriverConfig": @{ @"enabled": @NO }, @"gkeBackupAgentConfig": @{ @"enabled": @NO }, @"horizontalPodAutoscaling": @{ @"disabled": @NO }, @"httpLoadBalancing": @{ @"disabled": @NO }, @"istioConfig": @{ @"auth": @"", @"disabled": @NO }, @"kalmConfig": @{ @"enabled": @NO }, @"kubernetesDashboard": @{ @"disabled": @NO }, @"networkPolicyConfig": @{ @"disabled": @NO } }, @"desiredAuthenticatorGroupsConfig": @{ @"enabled": @NO, @"securityGroup": @"" }, @"desiredBinaryAuthorization": @{ @"enabled": @NO, @"evaluationMode": @"" }, @"desiredClusterAutoscaling": @{ @"autoprovisioningLocations": @[  ], @"autoprovisioningNodePoolDefaults": @{ @"bootDiskKmsKey": @"", @"diskSizeGb": @0, @"diskType": @"", @"imageType": @"", @"management": @{ @"autoRepair": @NO, @"autoUpgrade": @NO, @"upgradeOptions": @{ @"autoUpgradeStartTime": @"", @"description": @"" } }, @"minCpuPlatform": @"", @"oauthScopes": @[  ], @"serviceAccount": @"", @"shieldedInstanceConfig": @{ @"enableIntegrityMonitoring": @NO, @"enableSecureBoot": @NO }, @"upgradeSettings": @{ @"blueGreenSettings": @{ @"nodePoolSoakDuration": @"", @"standardRolloutPolicy": @{ @"batchNodeCount": @0, @"batchPercentage": @"", @"batchSoakDuration": @"" } }, @"maxSurge": @0, @"maxUnavailable": @0, @"strategy": @"" } }, @"autoscalingProfile": @"", @"enableNodeAutoprovisioning": @NO, @"resourceLimits": @[ @{ @"maximum": @"", @"minimum": @"", @"resourceType": @"" } ] }, @"desiredClusterTelemetry": @{ @"type": @"" }, @"desiredCostManagementConfig": @{ @"enabled": @NO }, @"desiredDatabaseEncryption": @{ @"keyName": @"", @"state": @"" }, @"desiredDatapathProvider": @"", @"desiredDefaultSnatStatus": @{ @"disabled": @NO }, @"desiredDnsConfig": @{ @"clusterDns": @"", @"clusterDnsDomain": @"", @"clusterDnsScope": @"" }, @"desiredEnablePrivateEndpoint": @NO, @"desiredGatewayApiConfig": @{ @"channel": @"" }, @"desiredGcfsConfig": @{ @"enabled": @NO }, @"desiredIdentityServiceConfig": @{ @"enabled": @NO }, @"desiredImageType": @"", @"desiredIntraNodeVisibilityConfig": @{ @"enabled": @NO }, @"desiredL4ilbSubsettingConfig": @{ @"enabled": @NO }, @"desiredLocations": @[  ], @"desiredLoggingConfig": @{ @"componentConfig": @{ @"enableComponents": @[  ] } }, @"desiredLoggingService": @"", @"desiredMaster": @{  }, @"desiredMasterAuthorizedNetworksConfig": @{ @"cidrBlocks": @[ @{ @"cidrBlock": @"", @"displayName": @"" } ], @"enabled": @NO, @"gcpPublicCidrsAccessEnabled": @NO }, @"desiredMasterVersion": @"", @"desiredMeshCertificates": @{ @"enableCertificates": @NO }, @"desiredMonitoringConfig": @{ @"componentConfig": @{ @"enableComponents": @[  ] }, @"managedPrometheusConfig": @{ @"enabled": @NO } }, @"desiredMonitoringService": @"", @"desiredNodePoolAutoConfigNetworkTags": @{ @"tags": @[  ] }, @"desiredNodePoolAutoscaling": @{ @"autoprovisioned": @NO, @"enabled": @NO, @"locationPolicy": @"", @"maxNodeCount": @0, @"minNodeCount": @0, @"totalMaxNodeCount": @0, @"totalMinNodeCount": @0 }, @"desiredNodePoolId": @"", @"desiredNodePoolLoggingConfig": @{ @"variantConfig": @{ @"variant": @"" } }, @"desiredNodeVersion": @"", @"desiredNotificationConfig": @{ @"pubsub": @{ @"enabled": @NO, @"filter": @{ @"eventType": @[  ] }, @"topic": @"" } }, @"desiredPodSecurityPolicyConfig": @{ @"enabled": @NO }, @"desiredPrivateClusterConfig": @{ @"enablePrivateEndpoint": @NO, @"enablePrivateNodes": @NO, @"masterGlobalAccessConfig": @{ @"enabled": @NO }, @"masterIpv4CidrBlock": @"", @"peeringName": @"", @"privateEndpoint": @"", @"privateEndpointSubnetwork": @"", @"publicEndpoint": @"" }, @"desiredPrivateIpv6GoogleAccess": @"", @"desiredProtectConfig": @{ @"workloadConfig": @{ @"auditMode": @"" }, @"workloadVulnerabilityMode": @"" }, @"desiredReleaseChannel": @{ @"channel": @"" }, @"desiredResourceUsageExportConfig": @{ @"bigqueryDestination": @{ @"datasetId": @"" }, @"consumptionMeteringConfig": @{ @"enabled": @NO }, @"enableNetworkEgressMetering": @NO }, @"desiredServiceExternalIpsConfig": @{ @"enabled": @NO }, @"desiredShieldedNodes": @{ @"enabled": @NO }, @"desiredStackType": @"", @"desiredTpuConfig": @{ @"enabled": @NO, @"ipv4CidrBlock": @"", @"useServiceNetworking": @NO }, @"desiredVerticalPodAutoscaling": @{ @"enabled": @NO }, @"desiredWorkloadAltsConfig": @{ @"enableAlts": @NO }, @"desiredWorkloadCertificates": @{ @"enableCertificates": @NO }, @"desiredWorkloadIdentityConfig": @{ @"identityNamespace": @"", @"identityProvider": @"", @"workloadPool": @"" }, @"etag": @"", @"removedAdditionalPodRangesConfig": @{  } },
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId",
  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([
    'clusterId' => '',
    'name' => '',
    'projectId' => '',
    'update' => [
        'additionalPodRangesConfig' => [
                'podRangeNames' => [
                                
                ]
        ],
        'desiredAddonsConfig' => [
                'cloudRunConfig' => [
                                'disabled' => null,
                                'loadBalancerType' => ''
                ],
                'configConnectorConfig' => [
                                'enabled' => null
                ],
                'dnsCacheConfig' => [
                                'enabled' => null
                ],
                'gcePersistentDiskCsiDriverConfig' => [
                                'enabled' => null
                ],
                'gcpFilestoreCsiDriverConfig' => [
                                'enabled' => null
                ],
                'gkeBackupAgentConfig' => [
                                'enabled' => null
                ],
                'horizontalPodAutoscaling' => [
                                'disabled' => null
                ],
                'httpLoadBalancing' => [
                                'disabled' => null
                ],
                'istioConfig' => [
                                'auth' => '',
                                'disabled' => null
                ],
                'kalmConfig' => [
                                'enabled' => null
                ],
                'kubernetesDashboard' => [
                                'disabled' => null
                ],
                'networkPolicyConfig' => [
                                'disabled' => null
                ]
        ],
        'desiredAuthenticatorGroupsConfig' => [
                'enabled' => null,
                'securityGroup' => ''
        ],
        'desiredBinaryAuthorization' => [
                'enabled' => null,
                'evaluationMode' => ''
        ],
        'desiredClusterAutoscaling' => [
                'autoprovisioningLocations' => [
                                
                ],
                'autoprovisioningNodePoolDefaults' => [
                                'bootDiskKmsKey' => '',
                                'diskSizeGb' => 0,
                                'diskType' => '',
                                'imageType' => '',
                                'management' => [
                                                                'autoRepair' => null,
                                                                'autoUpgrade' => null,
                                                                'upgradeOptions' => [
                                                                                                                                'autoUpgradeStartTime' => '',
                                                                                                                                'description' => ''
                                                                ]
                                ],
                                'minCpuPlatform' => '',
                                'oauthScopes' => [
                                                                
                                ],
                                'serviceAccount' => '',
                                'shieldedInstanceConfig' => [
                                                                'enableIntegrityMonitoring' => null,
                                                                'enableSecureBoot' => null
                                ],
                                'upgradeSettings' => [
                                                                'blueGreenSettings' => [
                                                                                                                                'nodePoolSoakDuration' => '',
                                                                                                                                'standardRolloutPolicy' => [
                                                                                                                                                                                                                                                                'batchNodeCount' => 0,
                                                                                                                                                                                                                                                                'batchPercentage' => '',
                                                                                                                                                                                                                                                                'batchSoakDuration' => ''
                                                                                                                                ]
                                                                ],
                                                                'maxSurge' => 0,
                                                                'maxUnavailable' => 0,
                                                                'strategy' => ''
                                ]
                ],
                'autoscalingProfile' => '',
                'enableNodeAutoprovisioning' => null,
                'resourceLimits' => [
                                [
                                                                'maximum' => '',
                                                                'minimum' => '',
                                                                'resourceType' => ''
                                ]
                ]
        ],
        'desiredClusterTelemetry' => [
                'type' => ''
        ],
        'desiredCostManagementConfig' => [
                'enabled' => null
        ],
        'desiredDatabaseEncryption' => [
                'keyName' => '',
                'state' => ''
        ],
        'desiredDatapathProvider' => '',
        'desiredDefaultSnatStatus' => [
                'disabled' => null
        ],
        'desiredDnsConfig' => [
                'clusterDns' => '',
                'clusterDnsDomain' => '',
                'clusterDnsScope' => ''
        ],
        'desiredEnablePrivateEndpoint' => null,
        'desiredGatewayApiConfig' => [
                'channel' => ''
        ],
        'desiredGcfsConfig' => [
                'enabled' => null
        ],
        'desiredIdentityServiceConfig' => [
                'enabled' => null
        ],
        'desiredImageType' => '',
        'desiredIntraNodeVisibilityConfig' => [
                'enabled' => null
        ],
        'desiredL4ilbSubsettingConfig' => [
                'enabled' => null
        ],
        'desiredLocations' => [
                
        ],
        'desiredLoggingConfig' => [
                'componentConfig' => [
                                'enableComponents' => [
                                                                
                                ]
                ]
        ],
        'desiredLoggingService' => '',
        'desiredMaster' => [
                
        ],
        'desiredMasterAuthorizedNetworksConfig' => [
                'cidrBlocks' => [
                                [
                                                                'cidrBlock' => '',
                                                                'displayName' => ''
                                ]
                ],
                'enabled' => null,
                'gcpPublicCidrsAccessEnabled' => null
        ],
        'desiredMasterVersion' => '',
        'desiredMeshCertificates' => [
                'enableCertificates' => null
        ],
        'desiredMonitoringConfig' => [
                'componentConfig' => [
                                'enableComponents' => [
                                                                
                                ]
                ],
                'managedPrometheusConfig' => [
                                'enabled' => null
                ]
        ],
        'desiredMonitoringService' => '',
        'desiredNodePoolAutoConfigNetworkTags' => [
                'tags' => [
                                
                ]
        ],
        'desiredNodePoolAutoscaling' => [
                'autoprovisioned' => null,
                'enabled' => null,
                'locationPolicy' => '',
                'maxNodeCount' => 0,
                'minNodeCount' => 0,
                'totalMaxNodeCount' => 0,
                'totalMinNodeCount' => 0
        ],
        'desiredNodePoolId' => '',
        'desiredNodePoolLoggingConfig' => [
                'variantConfig' => [
                                'variant' => ''
                ]
        ],
        'desiredNodeVersion' => '',
        'desiredNotificationConfig' => [
                'pubsub' => [
                                'enabled' => null,
                                'filter' => [
                                                                'eventType' => [
                                                                                                                                
                                                                ]
                                ],
                                'topic' => ''
                ]
        ],
        'desiredPodSecurityPolicyConfig' => [
                'enabled' => null
        ],
        'desiredPrivateClusterConfig' => [
                'enablePrivateEndpoint' => null,
                'enablePrivateNodes' => null,
                'masterGlobalAccessConfig' => [
                                'enabled' => null
                ],
                'masterIpv4CidrBlock' => '',
                'peeringName' => '',
                'privateEndpoint' => '',
                'privateEndpointSubnetwork' => '',
                'publicEndpoint' => ''
        ],
        'desiredPrivateIpv6GoogleAccess' => '',
        'desiredProtectConfig' => [
                'workloadConfig' => [
                                'auditMode' => ''
                ],
                'workloadVulnerabilityMode' => ''
        ],
        'desiredReleaseChannel' => [
                'channel' => ''
        ],
        'desiredResourceUsageExportConfig' => [
                'bigqueryDestination' => [
                                'datasetId' => ''
                ],
                'consumptionMeteringConfig' => [
                                'enabled' => null
                ],
                'enableNetworkEgressMetering' => null
        ],
        'desiredServiceExternalIpsConfig' => [
                'enabled' => null
        ],
        'desiredShieldedNodes' => [
                'enabled' => null
        ],
        'desiredStackType' => '',
        'desiredTpuConfig' => [
                'enabled' => null,
                'ipv4CidrBlock' => '',
                'useServiceNetworking' => null
        ],
        'desiredVerticalPodAutoscaling' => [
                'enabled' => null
        ],
        'desiredWorkloadAltsConfig' => [
                'enableAlts' => null
        ],
        'desiredWorkloadCertificates' => [
                'enableCertificates' => null
        ],
        'desiredWorkloadIdentityConfig' => [
                'identityNamespace' => '',
                'identityProvider' => '',
                'workloadPool' => ''
        ],
        'etag' => '',
        'removedAdditionalPodRangesConfig' => [
                
        ]
    ],
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId', [
  'body' => '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "additionalPodRangesConfig": {
      "podRangeNames": []
    },
    "desiredAddonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "desiredAuthenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "desiredBinaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "desiredClusterAutoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "desiredClusterTelemetry": {
      "type": ""
    },
    "desiredCostManagementConfig": {
      "enabled": false
    },
    "desiredDatabaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "desiredDatapathProvider": "",
    "desiredDefaultSnatStatus": {
      "disabled": false
    },
    "desiredDnsConfig": {
      "clusterDns": "",
      "clusterDnsDomain": "",
      "clusterDnsScope": ""
    },
    "desiredEnablePrivateEndpoint": false,
    "desiredGatewayApiConfig": {
      "channel": ""
    },
    "desiredGcfsConfig": {
      "enabled": false
    },
    "desiredIdentityServiceConfig": {
      "enabled": false
    },
    "desiredImageType": "",
    "desiredIntraNodeVisibilityConfig": {
      "enabled": false
    },
    "desiredL4ilbSubsettingConfig": {
      "enabled": false
    },
    "desiredLocations": [],
    "desiredLoggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "desiredLoggingService": "",
    "desiredMaster": {},
    "desiredMasterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "desiredMasterVersion": "",
    "desiredMeshCertificates": {
      "enableCertificates": false
    },
    "desiredMonitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "desiredMonitoringService": "",
    "desiredNodePoolAutoConfigNetworkTags": {
      "tags": []
    },
    "desiredNodePoolAutoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "desiredNodePoolId": "",
    "desiredNodePoolLoggingConfig": {
      "variantConfig": {
        "variant": ""
      }
    },
    "desiredNodeVersion": "",
    "desiredNotificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "desiredPodSecurityPolicyConfig": {
      "enabled": false
    },
    "desiredPrivateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "desiredPrivateIpv6GoogleAccess": "",
    "desiredProtectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "desiredReleaseChannel": {
      "channel": ""
    },
    "desiredResourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "desiredServiceExternalIpsConfig": {
      "enabled": false
    },
    "desiredShieldedNodes": {
      "enabled": false
    },
    "desiredStackType": "",
    "desiredTpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "desiredVerticalPodAutoscaling": {
      "enabled": false
    },
    "desiredWorkloadAltsConfig": {
      "enableAlts": false
    },
    "desiredWorkloadCertificates": {
      "enableCertificates": false
    },
    "desiredWorkloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "etag": "",
    "removedAdditionalPodRangesConfig": {}
  },
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');
$request->setMethod(HTTP_METH_PUT);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'update' => [
    'additionalPodRangesConfig' => [
        'podRangeNames' => [
                
        ]
    ],
    'desiredAddonsConfig' => [
        'cloudRunConfig' => [
                'disabled' => null,
                'loadBalancerType' => ''
        ],
        'configConnectorConfig' => [
                'enabled' => null
        ],
        'dnsCacheConfig' => [
                'enabled' => null
        ],
        'gcePersistentDiskCsiDriverConfig' => [
                'enabled' => null
        ],
        'gcpFilestoreCsiDriverConfig' => [
                'enabled' => null
        ],
        'gkeBackupAgentConfig' => [
                'enabled' => null
        ],
        'horizontalPodAutoscaling' => [
                'disabled' => null
        ],
        'httpLoadBalancing' => [
                'disabled' => null
        ],
        'istioConfig' => [
                'auth' => '',
                'disabled' => null
        ],
        'kalmConfig' => [
                'enabled' => null
        ],
        'kubernetesDashboard' => [
                'disabled' => null
        ],
        'networkPolicyConfig' => [
                'disabled' => null
        ]
    ],
    'desiredAuthenticatorGroupsConfig' => [
        'enabled' => null,
        'securityGroup' => ''
    ],
    'desiredBinaryAuthorization' => [
        'enabled' => null,
        'evaluationMode' => ''
    ],
    'desiredClusterAutoscaling' => [
        'autoprovisioningLocations' => [
                
        ],
        'autoprovisioningNodePoolDefaults' => [
                'bootDiskKmsKey' => '',
                'diskSizeGb' => 0,
                'diskType' => '',
                'imageType' => '',
                'management' => [
                                'autoRepair' => null,
                                'autoUpgrade' => null,
                                'upgradeOptions' => [
                                                                'autoUpgradeStartTime' => '',
                                                                'description' => ''
                                ]
                ],
                'minCpuPlatform' => '',
                'oauthScopes' => [
                                
                ],
                'serviceAccount' => '',
                'shieldedInstanceConfig' => [
                                'enableIntegrityMonitoring' => null,
                                'enableSecureBoot' => null
                ],
                'upgradeSettings' => [
                                'blueGreenSettings' => [
                                                                'nodePoolSoakDuration' => '',
                                                                'standardRolloutPolicy' => [
                                                                                                                                'batchNodeCount' => 0,
                                                                                                                                'batchPercentage' => '',
                                                                                                                                'batchSoakDuration' => ''
                                                                ]
                                ],
                                'maxSurge' => 0,
                                'maxUnavailable' => 0,
                                'strategy' => ''
                ]
        ],
        'autoscalingProfile' => '',
        'enableNodeAutoprovisioning' => null,
        'resourceLimits' => [
                [
                                'maximum' => '',
                                'minimum' => '',
                                'resourceType' => ''
                ]
        ]
    ],
    'desiredClusterTelemetry' => [
        'type' => ''
    ],
    'desiredCostManagementConfig' => [
        'enabled' => null
    ],
    'desiredDatabaseEncryption' => [
        'keyName' => '',
        'state' => ''
    ],
    'desiredDatapathProvider' => '',
    'desiredDefaultSnatStatus' => [
        'disabled' => null
    ],
    'desiredDnsConfig' => [
        'clusterDns' => '',
        'clusterDnsDomain' => '',
        'clusterDnsScope' => ''
    ],
    'desiredEnablePrivateEndpoint' => null,
    'desiredGatewayApiConfig' => [
        'channel' => ''
    ],
    'desiredGcfsConfig' => [
        'enabled' => null
    ],
    'desiredIdentityServiceConfig' => [
        'enabled' => null
    ],
    'desiredImageType' => '',
    'desiredIntraNodeVisibilityConfig' => [
        'enabled' => null
    ],
    'desiredL4ilbSubsettingConfig' => [
        'enabled' => null
    ],
    'desiredLocations' => [
        
    ],
    'desiredLoggingConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ]
    ],
    'desiredLoggingService' => '',
    'desiredMaster' => [
        
    ],
    'desiredMasterAuthorizedNetworksConfig' => [
        'cidrBlocks' => [
                [
                                'cidrBlock' => '',
                                'displayName' => ''
                ]
        ],
        'enabled' => null,
        'gcpPublicCidrsAccessEnabled' => null
    ],
    'desiredMasterVersion' => '',
    'desiredMeshCertificates' => [
        'enableCertificates' => null
    ],
    'desiredMonitoringConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ],
        'managedPrometheusConfig' => [
                'enabled' => null
        ]
    ],
    'desiredMonitoringService' => '',
    'desiredNodePoolAutoConfigNetworkTags' => [
        'tags' => [
                
        ]
    ],
    'desiredNodePoolAutoscaling' => [
        'autoprovisioned' => null,
        'enabled' => null,
        'locationPolicy' => '',
        'maxNodeCount' => 0,
        'minNodeCount' => 0,
        'totalMaxNodeCount' => 0,
        'totalMinNodeCount' => 0
    ],
    'desiredNodePoolId' => '',
    'desiredNodePoolLoggingConfig' => [
        'variantConfig' => [
                'variant' => ''
        ]
    ],
    'desiredNodeVersion' => '',
    'desiredNotificationConfig' => [
        'pubsub' => [
                'enabled' => null,
                'filter' => [
                                'eventType' => [
                                                                
                                ]
                ],
                'topic' => ''
        ]
    ],
    'desiredPodSecurityPolicyConfig' => [
        'enabled' => null
    ],
    'desiredPrivateClusterConfig' => [
        'enablePrivateEndpoint' => null,
        'enablePrivateNodes' => null,
        'masterGlobalAccessConfig' => [
                'enabled' => null
        ],
        'masterIpv4CidrBlock' => '',
        'peeringName' => '',
        'privateEndpoint' => '',
        'privateEndpointSubnetwork' => '',
        'publicEndpoint' => ''
    ],
    'desiredPrivateIpv6GoogleAccess' => '',
    'desiredProtectConfig' => [
        'workloadConfig' => [
                'auditMode' => ''
        ],
        'workloadVulnerabilityMode' => ''
    ],
    'desiredReleaseChannel' => [
        'channel' => ''
    ],
    'desiredResourceUsageExportConfig' => [
        'bigqueryDestination' => [
                'datasetId' => ''
        ],
        'consumptionMeteringConfig' => [
                'enabled' => null
        ],
        'enableNetworkEgressMetering' => null
    ],
    'desiredServiceExternalIpsConfig' => [
        'enabled' => null
    ],
    'desiredShieldedNodes' => [
        'enabled' => null
    ],
    'desiredStackType' => '',
    'desiredTpuConfig' => [
        'enabled' => null,
        'ipv4CidrBlock' => '',
        'useServiceNetworking' => null
    ],
    'desiredVerticalPodAutoscaling' => [
        'enabled' => null
    ],
    'desiredWorkloadAltsConfig' => [
        'enableAlts' => null
    ],
    'desiredWorkloadCertificates' => [
        'enableCertificates' => null
    ],
    'desiredWorkloadIdentityConfig' => [
        'identityNamespace' => '',
        'identityProvider' => '',
        'workloadPool' => ''
    ],
    'etag' => '',
    'removedAdditionalPodRangesConfig' => [
        
    ]
  ],
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'clusterId' => '',
  'name' => '',
  'projectId' => '',
  'update' => [
    'additionalPodRangesConfig' => [
        'podRangeNames' => [
                
        ]
    ],
    'desiredAddonsConfig' => [
        'cloudRunConfig' => [
                'disabled' => null,
                'loadBalancerType' => ''
        ],
        'configConnectorConfig' => [
                'enabled' => null
        ],
        'dnsCacheConfig' => [
                'enabled' => null
        ],
        'gcePersistentDiskCsiDriverConfig' => [
                'enabled' => null
        ],
        'gcpFilestoreCsiDriverConfig' => [
                'enabled' => null
        ],
        'gkeBackupAgentConfig' => [
                'enabled' => null
        ],
        'horizontalPodAutoscaling' => [
                'disabled' => null
        ],
        'httpLoadBalancing' => [
                'disabled' => null
        ],
        'istioConfig' => [
                'auth' => '',
                'disabled' => null
        ],
        'kalmConfig' => [
                'enabled' => null
        ],
        'kubernetesDashboard' => [
                'disabled' => null
        ],
        'networkPolicyConfig' => [
                'disabled' => null
        ]
    ],
    'desiredAuthenticatorGroupsConfig' => [
        'enabled' => null,
        'securityGroup' => ''
    ],
    'desiredBinaryAuthorization' => [
        'enabled' => null,
        'evaluationMode' => ''
    ],
    'desiredClusterAutoscaling' => [
        'autoprovisioningLocations' => [
                
        ],
        'autoprovisioningNodePoolDefaults' => [
                'bootDiskKmsKey' => '',
                'diskSizeGb' => 0,
                'diskType' => '',
                'imageType' => '',
                'management' => [
                                'autoRepair' => null,
                                'autoUpgrade' => null,
                                'upgradeOptions' => [
                                                                'autoUpgradeStartTime' => '',
                                                                'description' => ''
                                ]
                ],
                'minCpuPlatform' => '',
                'oauthScopes' => [
                                
                ],
                'serviceAccount' => '',
                'shieldedInstanceConfig' => [
                                'enableIntegrityMonitoring' => null,
                                'enableSecureBoot' => null
                ],
                'upgradeSettings' => [
                                'blueGreenSettings' => [
                                                                'nodePoolSoakDuration' => '',
                                                                'standardRolloutPolicy' => [
                                                                                                                                'batchNodeCount' => 0,
                                                                                                                                'batchPercentage' => '',
                                                                                                                                'batchSoakDuration' => ''
                                                                ]
                                ],
                                'maxSurge' => 0,
                                'maxUnavailable' => 0,
                                'strategy' => ''
                ]
        ],
        'autoscalingProfile' => '',
        'enableNodeAutoprovisioning' => null,
        'resourceLimits' => [
                [
                                'maximum' => '',
                                'minimum' => '',
                                'resourceType' => ''
                ]
        ]
    ],
    'desiredClusterTelemetry' => [
        'type' => ''
    ],
    'desiredCostManagementConfig' => [
        'enabled' => null
    ],
    'desiredDatabaseEncryption' => [
        'keyName' => '',
        'state' => ''
    ],
    'desiredDatapathProvider' => '',
    'desiredDefaultSnatStatus' => [
        'disabled' => null
    ],
    'desiredDnsConfig' => [
        'clusterDns' => '',
        'clusterDnsDomain' => '',
        'clusterDnsScope' => ''
    ],
    'desiredEnablePrivateEndpoint' => null,
    'desiredGatewayApiConfig' => [
        'channel' => ''
    ],
    'desiredGcfsConfig' => [
        'enabled' => null
    ],
    'desiredIdentityServiceConfig' => [
        'enabled' => null
    ],
    'desiredImageType' => '',
    'desiredIntraNodeVisibilityConfig' => [
        'enabled' => null
    ],
    'desiredL4ilbSubsettingConfig' => [
        'enabled' => null
    ],
    'desiredLocations' => [
        
    ],
    'desiredLoggingConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ]
    ],
    'desiredLoggingService' => '',
    'desiredMaster' => [
        
    ],
    'desiredMasterAuthorizedNetworksConfig' => [
        'cidrBlocks' => [
                [
                                'cidrBlock' => '',
                                'displayName' => ''
                ]
        ],
        'enabled' => null,
        'gcpPublicCidrsAccessEnabled' => null
    ],
    'desiredMasterVersion' => '',
    'desiredMeshCertificates' => [
        'enableCertificates' => null
    ],
    'desiredMonitoringConfig' => [
        'componentConfig' => [
                'enableComponents' => [
                                
                ]
        ],
        'managedPrometheusConfig' => [
                'enabled' => null
        ]
    ],
    'desiredMonitoringService' => '',
    'desiredNodePoolAutoConfigNetworkTags' => [
        'tags' => [
                
        ]
    ],
    'desiredNodePoolAutoscaling' => [
        'autoprovisioned' => null,
        'enabled' => null,
        'locationPolicy' => '',
        'maxNodeCount' => 0,
        'minNodeCount' => 0,
        'totalMaxNodeCount' => 0,
        'totalMinNodeCount' => 0
    ],
    'desiredNodePoolId' => '',
    'desiredNodePoolLoggingConfig' => [
        'variantConfig' => [
                'variant' => ''
        ]
    ],
    'desiredNodeVersion' => '',
    'desiredNotificationConfig' => [
        'pubsub' => [
                'enabled' => null,
                'filter' => [
                                'eventType' => [
                                                                
                                ]
                ],
                'topic' => ''
        ]
    ],
    'desiredPodSecurityPolicyConfig' => [
        'enabled' => null
    ],
    'desiredPrivateClusterConfig' => [
        'enablePrivateEndpoint' => null,
        'enablePrivateNodes' => null,
        'masterGlobalAccessConfig' => [
                'enabled' => null
        ],
        'masterIpv4CidrBlock' => '',
        'peeringName' => '',
        'privateEndpoint' => '',
        'privateEndpointSubnetwork' => '',
        'publicEndpoint' => ''
    ],
    'desiredPrivateIpv6GoogleAccess' => '',
    'desiredProtectConfig' => [
        'workloadConfig' => [
                'auditMode' => ''
        ],
        'workloadVulnerabilityMode' => ''
    ],
    'desiredReleaseChannel' => [
        'channel' => ''
    ],
    'desiredResourceUsageExportConfig' => [
        'bigqueryDestination' => [
                'datasetId' => ''
        ],
        'consumptionMeteringConfig' => [
                'enabled' => null
        ],
        'enableNetworkEgressMetering' => null
    ],
    'desiredServiceExternalIpsConfig' => [
        'enabled' => null
    ],
    'desiredShieldedNodes' => [
        'enabled' => null
    ],
    'desiredStackType' => '',
    'desiredTpuConfig' => [
        'enabled' => null,
        'ipv4CidrBlock' => '',
        'useServiceNetworking' => null
    ],
    'desiredVerticalPodAutoscaling' => [
        'enabled' => null
    ],
    'desiredWorkloadAltsConfig' => [
        'enableAlts' => null
    ],
    'desiredWorkloadCertificates' => [
        'enableCertificates' => null
    ],
    'desiredWorkloadIdentityConfig' => [
        'identityNamespace' => '',
        'identityProvider' => '',
        'workloadPool' => ''
    ],
    'etag' => '',
    'removedAdditionalPodRangesConfig' => [
        
    ]
  ],
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId');
$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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "additionalPodRangesConfig": {
      "podRangeNames": []
    },
    "desiredAddonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "desiredAuthenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "desiredBinaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "desiredClusterAutoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "desiredClusterTelemetry": {
      "type": ""
    },
    "desiredCostManagementConfig": {
      "enabled": false
    },
    "desiredDatabaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "desiredDatapathProvider": "",
    "desiredDefaultSnatStatus": {
      "disabled": false
    },
    "desiredDnsConfig": {
      "clusterDns": "",
      "clusterDnsDomain": "",
      "clusterDnsScope": ""
    },
    "desiredEnablePrivateEndpoint": false,
    "desiredGatewayApiConfig": {
      "channel": ""
    },
    "desiredGcfsConfig": {
      "enabled": false
    },
    "desiredIdentityServiceConfig": {
      "enabled": false
    },
    "desiredImageType": "",
    "desiredIntraNodeVisibilityConfig": {
      "enabled": false
    },
    "desiredL4ilbSubsettingConfig": {
      "enabled": false
    },
    "desiredLocations": [],
    "desiredLoggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "desiredLoggingService": "",
    "desiredMaster": {},
    "desiredMasterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "desiredMasterVersion": "",
    "desiredMeshCertificates": {
      "enableCertificates": false
    },
    "desiredMonitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "desiredMonitoringService": "",
    "desiredNodePoolAutoConfigNetworkTags": {
      "tags": []
    },
    "desiredNodePoolAutoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "desiredNodePoolId": "",
    "desiredNodePoolLoggingConfig": {
      "variantConfig": {
        "variant": ""
      }
    },
    "desiredNodeVersion": "",
    "desiredNotificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "desiredPodSecurityPolicyConfig": {
      "enabled": false
    },
    "desiredPrivateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "desiredPrivateIpv6GoogleAccess": "",
    "desiredProtectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "desiredReleaseChannel": {
      "channel": ""
    },
    "desiredResourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "desiredServiceExternalIpsConfig": {
      "enabled": false
    },
    "desiredShieldedNodes": {
      "enabled": false
    },
    "desiredStackType": "",
    "desiredTpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "desiredVerticalPodAutoscaling": {
      "enabled": false
    },
    "desiredWorkloadAltsConfig": {
      "enableAlts": false
    },
    "desiredWorkloadCertificates": {
      "enableCertificates": false
    },
    "desiredWorkloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "etag": "",
    "removedAdditionalPodRangesConfig": {}
  },
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "additionalPodRangesConfig": {
      "podRangeNames": []
    },
    "desiredAddonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "desiredAuthenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "desiredBinaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "desiredClusterAutoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "desiredClusterTelemetry": {
      "type": ""
    },
    "desiredCostManagementConfig": {
      "enabled": false
    },
    "desiredDatabaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "desiredDatapathProvider": "",
    "desiredDefaultSnatStatus": {
      "disabled": false
    },
    "desiredDnsConfig": {
      "clusterDns": "",
      "clusterDnsDomain": "",
      "clusterDnsScope": ""
    },
    "desiredEnablePrivateEndpoint": false,
    "desiredGatewayApiConfig": {
      "channel": ""
    },
    "desiredGcfsConfig": {
      "enabled": false
    },
    "desiredIdentityServiceConfig": {
      "enabled": false
    },
    "desiredImageType": "",
    "desiredIntraNodeVisibilityConfig": {
      "enabled": false
    },
    "desiredL4ilbSubsettingConfig": {
      "enabled": false
    },
    "desiredLocations": [],
    "desiredLoggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "desiredLoggingService": "",
    "desiredMaster": {},
    "desiredMasterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "desiredMasterVersion": "",
    "desiredMeshCertificates": {
      "enableCertificates": false
    },
    "desiredMonitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "desiredMonitoringService": "",
    "desiredNodePoolAutoConfigNetworkTags": {
      "tags": []
    },
    "desiredNodePoolAutoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "desiredNodePoolId": "",
    "desiredNodePoolLoggingConfig": {
      "variantConfig": {
        "variant": ""
      }
    },
    "desiredNodeVersion": "",
    "desiredNotificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "desiredPodSecurityPolicyConfig": {
      "enabled": false
    },
    "desiredPrivateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "desiredPrivateIpv6GoogleAccess": "",
    "desiredProtectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "desiredReleaseChannel": {
      "channel": ""
    },
    "desiredResourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "desiredServiceExternalIpsConfig": {
      "enabled": false
    },
    "desiredShieldedNodes": {
      "enabled": false
    },
    "desiredStackType": "",
    "desiredTpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "desiredVerticalPodAutoscaling": {
      "enabled": false
    },
    "desiredWorkloadAltsConfig": {
      "enableAlts": false
    },
    "desiredWorkloadCertificates": {
      "enableCertificates": false
    },
    "desiredWorkloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "etag": "",
    "removedAdditionalPodRangesConfig": {}
  },
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PUT", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"

payload = {
    "clusterId": "",
    "name": "",
    "projectId": "",
    "update": {
        "additionalPodRangesConfig": { "podRangeNames": [] },
        "desiredAddonsConfig": {
            "cloudRunConfig": {
                "disabled": False,
                "loadBalancerType": ""
            },
            "configConnectorConfig": { "enabled": False },
            "dnsCacheConfig": { "enabled": False },
            "gcePersistentDiskCsiDriverConfig": { "enabled": False },
            "gcpFilestoreCsiDriverConfig": { "enabled": False },
            "gkeBackupAgentConfig": { "enabled": False },
            "horizontalPodAutoscaling": { "disabled": False },
            "httpLoadBalancing": { "disabled": False },
            "istioConfig": {
                "auth": "",
                "disabled": False
            },
            "kalmConfig": { "enabled": False },
            "kubernetesDashboard": { "disabled": False },
            "networkPolicyConfig": { "disabled": False }
        },
        "desiredAuthenticatorGroupsConfig": {
            "enabled": False,
            "securityGroup": ""
        },
        "desiredBinaryAuthorization": {
            "enabled": False,
            "evaluationMode": ""
        },
        "desiredClusterAutoscaling": {
            "autoprovisioningLocations": [],
            "autoprovisioningNodePoolDefaults": {
                "bootDiskKmsKey": "",
                "diskSizeGb": 0,
                "diskType": "",
                "imageType": "",
                "management": {
                    "autoRepair": False,
                    "autoUpgrade": False,
                    "upgradeOptions": {
                        "autoUpgradeStartTime": "",
                        "description": ""
                    }
                },
                "minCpuPlatform": "",
                "oauthScopes": [],
                "serviceAccount": "",
                "shieldedInstanceConfig": {
                    "enableIntegrityMonitoring": False,
                    "enableSecureBoot": False
                },
                "upgradeSettings": {
                    "blueGreenSettings": {
                        "nodePoolSoakDuration": "",
                        "standardRolloutPolicy": {
                            "batchNodeCount": 0,
                            "batchPercentage": "",
                            "batchSoakDuration": ""
                        }
                    },
                    "maxSurge": 0,
                    "maxUnavailable": 0,
                    "strategy": ""
                }
            },
            "autoscalingProfile": "",
            "enableNodeAutoprovisioning": False,
            "resourceLimits": [
                {
                    "maximum": "",
                    "minimum": "",
                    "resourceType": ""
                }
            ]
        },
        "desiredClusterTelemetry": { "type": "" },
        "desiredCostManagementConfig": { "enabled": False },
        "desiredDatabaseEncryption": {
            "keyName": "",
            "state": ""
        },
        "desiredDatapathProvider": "",
        "desiredDefaultSnatStatus": { "disabled": False },
        "desiredDnsConfig": {
            "clusterDns": "",
            "clusterDnsDomain": "",
            "clusterDnsScope": ""
        },
        "desiredEnablePrivateEndpoint": False,
        "desiredGatewayApiConfig": { "channel": "" },
        "desiredGcfsConfig": { "enabled": False },
        "desiredIdentityServiceConfig": { "enabled": False },
        "desiredImageType": "",
        "desiredIntraNodeVisibilityConfig": { "enabled": False },
        "desiredL4ilbSubsettingConfig": { "enabled": False },
        "desiredLocations": [],
        "desiredLoggingConfig": { "componentConfig": { "enableComponents": [] } },
        "desiredLoggingService": "",
        "desiredMaster": {},
        "desiredMasterAuthorizedNetworksConfig": {
            "cidrBlocks": [
                {
                    "cidrBlock": "",
                    "displayName": ""
                }
            ],
            "enabled": False,
            "gcpPublicCidrsAccessEnabled": False
        },
        "desiredMasterVersion": "",
        "desiredMeshCertificates": { "enableCertificates": False },
        "desiredMonitoringConfig": {
            "componentConfig": { "enableComponents": [] },
            "managedPrometheusConfig": { "enabled": False }
        },
        "desiredMonitoringService": "",
        "desiredNodePoolAutoConfigNetworkTags": { "tags": [] },
        "desiredNodePoolAutoscaling": {
            "autoprovisioned": False,
            "enabled": False,
            "locationPolicy": "",
            "maxNodeCount": 0,
            "minNodeCount": 0,
            "totalMaxNodeCount": 0,
            "totalMinNodeCount": 0
        },
        "desiredNodePoolId": "",
        "desiredNodePoolLoggingConfig": { "variantConfig": { "variant": "" } },
        "desiredNodeVersion": "",
        "desiredNotificationConfig": { "pubsub": {
                "enabled": False,
                "filter": { "eventType": [] },
                "topic": ""
            } },
        "desiredPodSecurityPolicyConfig": { "enabled": False },
        "desiredPrivateClusterConfig": {
            "enablePrivateEndpoint": False,
            "enablePrivateNodes": False,
            "masterGlobalAccessConfig": { "enabled": False },
            "masterIpv4CidrBlock": "",
            "peeringName": "",
            "privateEndpoint": "",
            "privateEndpointSubnetwork": "",
            "publicEndpoint": ""
        },
        "desiredPrivateIpv6GoogleAccess": "",
        "desiredProtectConfig": {
            "workloadConfig": { "auditMode": "" },
            "workloadVulnerabilityMode": ""
        },
        "desiredReleaseChannel": { "channel": "" },
        "desiredResourceUsageExportConfig": {
            "bigqueryDestination": { "datasetId": "" },
            "consumptionMeteringConfig": { "enabled": False },
            "enableNetworkEgressMetering": False
        },
        "desiredServiceExternalIpsConfig": { "enabled": False },
        "desiredShieldedNodes": { "enabled": False },
        "desiredStackType": "",
        "desiredTpuConfig": {
            "enabled": False,
            "ipv4CidrBlock": "",
            "useServiceNetworking": False
        },
        "desiredVerticalPodAutoscaling": { "enabled": False },
        "desiredWorkloadAltsConfig": { "enableAlts": False },
        "desiredWorkloadCertificates": { "enableCertificates": False },
        "desiredWorkloadIdentityConfig": {
            "identityNamespace": "",
            "identityProvider": "",
            "workloadPool": ""
        },
        "etag": "",
        "removedAdditionalPodRangesConfig": {}
    },
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.put(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId"

payload <- "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")

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  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId') do |req|
  req.body = "{\n  \"clusterId\": \"\",\n  \"name\": \"\",\n  \"projectId\": \"\",\n  \"update\": {\n    \"additionalPodRangesConfig\": {\n      \"podRangeNames\": []\n    },\n    \"desiredAddonsConfig\": {\n      \"cloudRunConfig\": {\n        \"disabled\": false,\n        \"loadBalancerType\": \"\"\n      },\n      \"configConnectorConfig\": {\n        \"enabled\": false\n      },\n      \"dnsCacheConfig\": {\n        \"enabled\": false\n      },\n      \"gcePersistentDiskCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gcpFilestoreCsiDriverConfig\": {\n        \"enabled\": false\n      },\n      \"gkeBackupAgentConfig\": {\n        \"enabled\": false\n      },\n      \"horizontalPodAutoscaling\": {\n        \"disabled\": false\n      },\n      \"httpLoadBalancing\": {\n        \"disabled\": false\n      },\n      \"istioConfig\": {\n        \"auth\": \"\",\n        \"disabled\": false\n      },\n      \"kalmConfig\": {\n        \"enabled\": false\n      },\n      \"kubernetesDashboard\": {\n        \"disabled\": false\n      },\n      \"networkPolicyConfig\": {\n        \"disabled\": false\n      }\n    },\n    \"desiredAuthenticatorGroupsConfig\": {\n      \"enabled\": false,\n      \"securityGroup\": \"\"\n    },\n    \"desiredBinaryAuthorization\": {\n      \"enabled\": false,\n      \"evaluationMode\": \"\"\n    },\n    \"desiredClusterAutoscaling\": {\n      \"autoprovisioningLocations\": [],\n      \"autoprovisioningNodePoolDefaults\": {\n        \"bootDiskKmsKey\": \"\",\n        \"diskSizeGb\": 0,\n        \"diskType\": \"\",\n        \"imageType\": \"\",\n        \"management\": {\n          \"autoRepair\": false,\n          \"autoUpgrade\": false,\n          \"upgradeOptions\": {\n            \"autoUpgradeStartTime\": \"\",\n            \"description\": \"\"\n          }\n        },\n        \"minCpuPlatform\": \"\",\n        \"oauthScopes\": [],\n        \"serviceAccount\": \"\",\n        \"shieldedInstanceConfig\": {\n          \"enableIntegrityMonitoring\": false,\n          \"enableSecureBoot\": false\n        },\n        \"upgradeSettings\": {\n          \"blueGreenSettings\": {\n            \"nodePoolSoakDuration\": \"\",\n            \"standardRolloutPolicy\": {\n              \"batchNodeCount\": 0,\n              \"batchPercentage\": \"\",\n              \"batchSoakDuration\": \"\"\n            }\n          },\n          \"maxSurge\": 0,\n          \"maxUnavailable\": 0,\n          \"strategy\": \"\"\n        }\n      },\n      \"autoscalingProfile\": \"\",\n      \"enableNodeAutoprovisioning\": false,\n      \"resourceLimits\": [\n        {\n          \"maximum\": \"\",\n          \"minimum\": \"\",\n          \"resourceType\": \"\"\n        }\n      ]\n    },\n    \"desiredClusterTelemetry\": {\n      \"type\": \"\"\n    },\n    \"desiredCostManagementConfig\": {\n      \"enabled\": false\n    },\n    \"desiredDatabaseEncryption\": {\n      \"keyName\": \"\",\n      \"state\": \"\"\n    },\n    \"desiredDatapathProvider\": \"\",\n    \"desiredDefaultSnatStatus\": {\n      \"disabled\": false\n    },\n    \"desiredDnsConfig\": {\n      \"clusterDns\": \"\",\n      \"clusterDnsDomain\": \"\",\n      \"clusterDnsScope\": \"\"\n    },\n    \"desiredEnablePrivateEndpoint\": false,\n    \"desiredGatewayApiConfig\": {\n      \"channel\": \"\"\n    },\n    \"desiredGcfsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredIdentityServiceConfig\": {\n      \"enabled\": false\n    },\n    \"desiredImageType\": \"\",\n    \"desiredIntraNodeVisibilityConfig\": {\n      \"enabled\": false\n    },\n    \"desiredL4ilbSubsettingConfig\": {\n      \"enabled\": false\n    },\n    \"desiredLocations\": [],\n    \"desiredLoggingConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      }\n    },\n    \"desiredLoggingService\": \"\",\n    \"desiredMaster\": {},\n    \"desiredMasterAuthorizedNetworksConfig\": {\n      \"cidrBlocks\": [\n        {\n          \"cidrBlock\": \"\",\n          \"displayName\": \"\"\n        }\n      ],\n      \"enabled\": false,\n      \"gcpPublicCidrsAccessEnabled\": false\n    },\n    \"desiredMasterVersion\": \"\",\n    \"desiredMeshCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredMonitoringConfig\": {\n      \"componentConfig\": {\n        \"enableComponents\": []\n      },\n      \"managedPrometheusConfig\": {\n        \"enabled\": false\n      }\n    },\n    \"desiredMonitoringService\": \"\",\n    \"desiredNodePoolAutoConfigNetworkTags\": {\n      \"tags\": []\n    },\n    \"desiredNodePoolAutoscaling\": {\n      \"autoprovisioned\": false,\n      \"enabled\": false,\n      \"locationPolicy\": \"\",\n      \"maxNodeCount\": 0,\n      \"minNodeCount\": 0,\n      \"totalMaxNodeCount\": 0,\n      \"totalMinNodeCount\": 0\n    },\n    \"desiredNodePoolId\": \"\",\n    \"desiredNodePoolLoggingConfig\": {\n      \"variantConfig\": {\n        \"variant\": \"\"\n      }\n    },\n    \"desiredNodeVersion\": \"\",\n    \"desiredNotificationConfig\": {\n      \"pubsub\": {\n        \"enabled\": false,\n        \"filter\": {\n          \"eventType\": []\n        },\n        \"topic\": \"\"\n      }\n    },\n    \"desiredPodSecurityPolicyConfig\": {\n      \"enabled\": false\n    },\n    \"desiredPrivateClusterConfig\": {\n      \"enablePrivateEndpoint\": false,\n      \"enablePrivateNodes\": false,\n      \"masterGlobalAccessConfig\": {\n        \"enabled\": false\n      },\n      \"masterIpv4CidrBlock\": \"\",\n      \"peeringName\": \"\",\n      \"privateEndpoint\": \"\",\n      \"privateEndpointSubnetwork\": \"\",\n      \"publicEndpoint\": \"\"\n    },\n    \"desiredPrivateIpv6GoogleAccess\": \"\",\n    \"desiredProtectConfig\": {\n      \"workloadConfig\": {\n        \"auditMode\": \"\"\n      },\n      \"workloadVulnerabilityMode\": \"\"\n    },\n    \"desiredReleaseChannel\": {\n      \"channel\": \"\"\n    },\n    \"desiredResourceUsageExportConfig\": {\n      \"bigqueryDestination\": {\n        \"datasetId\": \"\"\n      },\n      \"consumptionMeteringConfig\": {\n        \"enabled\": false\n      },\n      \"enableNetworkEgressMetering\": false\n    },\n    \"desiredServiceExternalIpsConfig\": {\n      \"enabled\": false\n    },\n    \"desiredShieldedNodes\": {\n      \"enabled\": false\n    },\n    \"desiredStackType\": \"\",\n    \"desiredTpuConfig\": {\n      \"enabled\": false,\n      \"ipv4CidrBlock\": \"\",\n      \"useServiceNetworking\": false\n    },\n    \"desiredVerticalPodAutoscaling\": {\n      \"enabled\": false\n    },\n    \"desiredWorkloadAltsConfig\": {\n      \"enableAlts\": false\n    },\n    \"desiredWorkloadCertificates\": {\n      \"enableCertificates\": false\n    },\n    \"desiredWorkloadIdentityConfig\": {\n      \"identityNamespace\": \"\",\n      \"identityProvider\": \"\",\n      \"workloadPool\": \"\"\n    },\n    \"etag\": \"\",\n    \"removedAdditionalPodRangesConfig\": {}\n  },\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId";

    let payload = json!({
        "clusterId": "",
        "name": "",
        "projectId": "",
        "update": json!({
            "additionalPodRangesConfig": json!({"podRangeNames": ()}),
            "desiredAddonsConfig": json!({
                "cloudRunConfig": json!({
                    "disabled": false,
                    "loadBalancerType": ""
                }),
                "configConnectorConfig": json!({"enabled": false}),
                "dnsCacheConfig": json!({"enabled": false}),
                "gcePersistentDiskCsiDriverConfig": json!({"enabled": false}),
                "gcpFilestoreCsiDriverConfig": json!({"enabled": false}),
                "gkeBackupAgentConfig": json!({"enabled": false}),
                "horizontalPodAutoscaling": json!({"disabled": false}),
                "httpLoadBalancing": json!({"disabled": false}),
                "istioConfig": json!({
                    "auth": "",
                    "disabled": false
                }),
                "kalmConfig": json!({"enabled": false}),
                "kubernetesDashboard": json!({"disabled": false}),
                "networkPolicyConfig": json!({"disabled": false})
            }),
            "desiredAuthenticatorGroupsConfig": json!({
                "enabled": false,
                "securityGroup": ""
            }),
            "desiredBinaryAuthorization": json!({
                "enabled": false,
                "evaluationMode": ""
            }),
            "desiredClusterAutoscaling": json!({
                "autoprovisioningLocations": (),
                "autoprovisioningNodePoolDefaults": json!({
                    "bootDiskKmsKey": "",
                    "diskSizeGb": 0,
                    "diskType": "",
                    "imageType": "",
                    "management": json!({
                        "autoRepair": false,
                        "autoUpgrade": false,
                        "upgradeOptions": json!({
                            "autoUpgradeStartTime": "",
                            "description": ""
                        })
                    }),
                    "minCpuPlatform": "",
                    "oauthScopes": (),
                    "serviceAccount": "",
                    "shieldedInstanceConfig": json!({
                        "enableIntegrityMonitoring": false,
                        "enableSecureBoot": false
                    }),
                    "upgradeSettings": json!({
                        "blueGreenSettings": json!({
                            "nodePoolSoakDuration": "",
                            "standardRolloutPolicy": json!({
                                "batchNodeCount": 0,
                                "batchPercentage": "",
                                "batchSoakDuration": ""
                            })
                        }),
                        "maxSurge": 0,
                        "maxUnavailable": 0,
                        "strategy": ""
                    })
                }),
                "autoscalingProfile": "",
                "enableNodeAutoprovisioning": false,
                "resourceLimits": (
                    json!({
                        "maximum": "",
                        "minimum": "",
                        "resourceType": ""
                    })
                )
            }),
            "desiredClusterTelemetry": json!({"type": ""}),
            "desiredCostManagementConfig": json!({"enabled": false}),
            "desiredDatabaseEncryption": json!({
                "keyName": "",
                "state": ""
            }),
            "desiredDatapathProvider": "",
            "desiredDefaultSnatStatus": json!({"disabled": false}),
            "desiredDnsConfig": json!({
                "clusterDns": "",
                "clusterDnsDomain": "",
                "clusterDnsScope": ""
            }),
            "desiredEnablePrivateEndpoint": false,
            "desiredGatewayApiConfig": json!({"channel": ""}),
            "desiredGcfsConfig": json!({"enabled": false}),
            "desiredIdentityServiceConfig": json!({"enabled": false}),
            "desiredImageType": "",
            "desiredIntraNodeVisibilityConfig": json!({"enabled": false}),
            "desiredL4ilbSubsettingConfig": json!({"enabled": false}),
            "desiredLocations": (),
            "desiredLoggingConfig": json!({"componentConfig": json!({"enableComponents": ()})}),
            "desiredLoggingService": "",
            "desiredMaster": json!({}),
            "desiredMasterAuthorizedNetworksConfig": json!({
                "cidrBlocks": (
                    json!({
                        "cidrBlock": "",
                        "displayName": ""
                    })
                ),
                "enabled": false,
                "gcpPublicCidrsAccessEnabled": false
            }),
            "desiredMasterVersion": "",
            "desiredMeshCertificates": json!({"enableCertificates": false}),
            "desiredMonitoringConfig": json!({
                "componentConfig": json!({"enableComponents": ()}),
                "managedPrometheusConfig": json!({"enabled": false})
            }),
            "desiredMonitoringService": "",
            "desiredNodePoolAutoConfigNetworkTags": json!({"tags": ()}),
            "desiredNodePoolAutoscaling": json!({
                "autoprovisioned": false,
                "enabled": false,
                "locationPolicy": "",
                "maxNodeCount": 0,
                "minNodeCount": 0,
                "totalMaxNodeCount": 0,
                "totalMinNodeCount": 0
            }),
            "desiredNodePoolId": "",
            "desiredNodePoolLoggingConfig": json!({"variantConfig": json!({"variant": ""})}),
            "desiredNodeVersion": "",
            "desiredNotificationConfig": json!({"pubsub": json!({
                    "enabled": false,
                    "filter": json!({"eventType": ()}),
                    "topic": ""
                })}),
            "desiredPodSecurityPolicyConfig": json!({"enabled": false}),
            "desiredPrivateClusterConfig": json!({
                "enablePrivateEndpoint": false,
                "enablePrivateNodes": false,
                "masterGlobalAccessConfig": json!({"enabled": false}),
                "masterIpv4CidrBlock": "",
                "peeringName": "",
                "privateEndpoint": "",
                "privateEndpointSubnetwork": "",
                "publicEndpoint": ""
            }),
            "desiredPrivateIpv6GoogleAccess": "",
            "desiredProtectConfig": json!({
                "workloadConfig": json!({"auditMode": ""}),
                "workloadVulnerabilityMode": ""
            }),
            "desiredReleaseChannel": json!({"channel": ""}),
            "desiredResourceUsageExportConfig": json!({
                "bigqueryDestination": json!({"datasetId": ""}),
                "consumptionMeteringConfig": json!({"enabled": false}),
                "enableNetworkEgressMetering": false
            }),
            "desiredServiceExternalIpsConfig": json!({"enabled": false}),
            "desiredShieldedNodes": json!({"enabled": false}),
            "desiredStackType": "",
            "desiredTpuConfig": json!({
                "enabled": false,
                "ipv4CidrBlock": "",
                "useServiceNetworking": false
            }),
            "desiredVerticalPodAutoscaling": json!({"enabled": false}),
            "desiredWorkloadAltsConfig": json!({"enableAlts": false}),
            "desiredWorkloadCertificates": json!({"enableCertificates": false}),
            "desiredWorkloadIdentityConfig": json!({
                "identityNamespace": "",
                "identityProvider": "",
                "workloadPool": ""
            }),
            "etag": "",
            "removedAdditionalPodRangesConfig": json!({})
        }),
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId \
  --header 'content-type: application/json' \
  --data '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "additionalPodRangesConfig": {
      "podRangeNames": []
    },
    "desiredAddonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "desiredAuthenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "desiredBinaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "desiredClusterAutoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "desiredClusterTelemetry": {
      "type": ""
    },
    "desiredCostManagementConfig": {
      "enabled": false
    },
    "desiredDatabaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "desiredDatapathProvider": "",
    "desiredDefaultSnatStatus": {
      "disabled": false
    },
    "desiredDnsConfig": {
      "clusterDns": "",
      "clusterDnsDomain": "",
      "clusterDnsScope": ""
    },
    "desiredEnablePrivateEndpoint": false,
    "desiredGatewayApiConfig": {
      "channel": ""
    },
    "desiredGcfsConfig": {
      "enabled": false
    },
    "desiredIdentityServiceConfig": {
      "enabled": false
    },
    "desiredImageType": "",
    "desiredIntraNodeVisibilityConfig": {
      "enabled": false
    },
    "desiredL4ilbSubsettingConfig": {
      "enabled": false
    },
    "desiredLocations": [],
    "desiredLoggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "desiredLoggingService": "",
    "desiredMaster": {},
    "desiredMasterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "desiredMasterVersion": "",
    "desiredMeshCertificates": {
      "enableCertificates": false
    },
    "desiredMonitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "desiredMonitoringService": "",
    "desiredNodePoolAutoConfigNetworkTags": {
      "tags": []
    },
    "desiredNodePoolAutoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "desiredNodePoolId": "",
    "desiredNodePoolLoggingConfig": {
      "variantConfig": {
        "variant": ""
      }
    },
    "desiredNodeVersion": "",
    "desiredNotificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "desiredPodSecurityPolicyConfig": {
      "enabled": false
    },
    "desiredPrivateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "desiredPrivateIpv6GoogleAccess": "",
    "desiredProtectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "desiredReleaseChannel": {
      "channel": ""
    },
    "desiredResourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "desiredServiceExternalIpsConfig": {
      "enabled": false
    },
    "desiredShieldedNodes": {
      "enabled": false
    },
    "desiredStackType": "",
    "desiredTpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "desiredVerticalPodAutoscaling": {
      "enabled": false
    },
    "desiredWorkloadAltsConfig": {
      "enableAlts": false
    },
    "desiredWorkloadCertificates": {
      "enableCertificates": false
    },
    "desiredWorkloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "etag": "",
    "removedAdditionalPodRangesConfig": {}
  },
  "zone": ""
}'
echo '{
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": {
    "additionalPodRangesConfig": {
      "podRangeNames": []
    },
    "desiredAddonsConfig": {
      "cloudRunConfig": {
        "disabled": false,
        "loadBalancerType": ""
      },
      "configConnectorConfig": {
        "enabled": false
      },
      "dnsCacheConfig": {
        "enabled": false
      },
      "gcePersistentDiskCsiDriverConfig": {
        "enabled": false
      },
      "gcpFilestoreCsiDriverConfig": {
        "enabled": false
      },
      "gkeBackupAgentConfig": {
        "enabled": false
      },
      "horizontalPodAutoscaling": {
        "disabled": false
      },
      "httpLoadBalancing": {
        "disabled": false
      },
      "istioConfig": {
        "auth": "",
        "disabled": false
      },
      "kalmConfig": {
        "enabled": false
      },
      "kubernetesDashboard": {
        "disabled": false
      },
      "networkPolicyConfig": {
        "disabled": false
      }
    },
    "desiredAuthenticatorGroupsConfig": {
      "enabled": false,
      "securityGroup": ""
    },
    "desiredBinaryAuthorization": {
      "enabled": false,
      "evaluationMode": ""
    },
    "desiredClusterAutoscaling": {
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": {
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": {
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": {
            "autoUpgradeStartTime": "",
            "description": ""
          }
        },
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": {
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        },
        "upgradeSettings": {
          "blueGreenSettings": {
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": {
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            }
          },
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        }
      },
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        {
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        }
      ]
    },
    "desiredClusterTelemetry": {
      "type": ""
    },
    "desiredCostManagementConfig": {
      "enabled": false
    },
    "desiredDatabaseEncryption": {
      "keyName": "",
      "state": ""
    },
    "desiredDatapathProvider": "",
    "desiredDefaultSnatStatus": {
      "disabled": false
    },
    "desiredDnsConfig": {
      "clusterDns": "",
      "clusterDnsDomain": "",
      "clusterDnsScope": ""
    },
    "desiredEnablePrivateEndpoint": false,
    "desiredGatewayApiConfig": {
      "channel": ""
    },
    "desiredGcfsConfig": {
      "enabled": false
    },
    "desiredIdentityServiceConfig": {
      "enabled": false
    },
    "desiredImageType": "",
    "desiredIntraNodeVisibilityConfig": {
      "enabled": false
    },
    "desiredL4ilbSubsettingConfig": {
      "enabled": false
    },
    "desiredLocations": [],
    "desiredLoggingConfig": {
      "componentConfig": {
        "enableComponents": []
      }
    },
    "desiredLoggingService": "",
    "desiredMaster": {},
    "desiredMasterAuthorizedNetworksConfig": {
      "cidrBlocks": [
        {
          "cidrBlock": "",
          "displayName": ""
        }
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    },
    "desiredMasterVersion": "",
    "desiredMeshCertificates": {
      "enableCertificates": false
    },
    "desiredMonitoringConfig": {
      "componentConfig": {
        "enableComponents": []
      },
      "managedPrometheusConfig": {
        "enabled": false
      }
    },
    "desiredMonitoringService": "",
    "desiredNodePoolAutoConfigNetworkTags": {
      "tags": []
    },
    "desiredNodePoolAutoscaling": {
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    },
    "desiredNodePoolId": "",
    "desiredNodePoolLoggingConfig": {
      "variantConfig": {
        "variant": ""
      }
    },
    "desiredNodeVersion": "",
    "desiredNotificationConfig": {
      "pubsub": {
        "enabled": false,
        "filter": {
          "eventType": []
        },
        "topic": ""
      }
    },
    "desiredPodSecurityPolicyConfig": {
      "enabled": false
    },
    "desiredPrivateClusterConfig": {
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": {
        "enabled": false
      },
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    },
    "desiredPrivateIpv6GoogleAccess": "",
    "desiredProtectConfig": {
      "workloadConfig": {
        "auditMode": ""
      },
      "workloadVulnerabilityMode": ""
    },
    "desiredReleaseChannel": {
      "channel": ""
    },
    "desiredResourceUsageExportConfig": {
      "bigqueryDestination": {
        "datasetId": ""
      },
      "consumptionMeteringConfig": {
        "enabled": false
      },
      "enableNetworkEgressMetering": false
    },
    "desiredServiceExternalIpsConfig": {
      "enabled": false
    },
    "desiredShieldedNodes": {
      "enabled": false
    },
    "desiredStackType": "",
    "desiredTpuConfig": {
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    },
    "desiredVerticalPodAutoscaling": {
      "enabled": false
    },
    "desiredWorkloadAltsConfig": {
      "enableAlts": false
    },
    "desiredWorkloadCertificates": {
      "enableCertificates": false
    },
    "desiredWorkloadIdentityConfig": {
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    },
    "etag": "",
    "removedAdditionalPodRangesConfig": {}
  },
  "zone": ""
}' |  \
  http PUT {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "clusterId": "",\n  "name": "",\n  "projectId": "",\n  "update": {\n    "additionalPodRangesConfig": {\n      "podRangeNames": []\n    },\n    "desiredAddonsConfig": {\n      "cloudRunConfig": {\n        "disabled": false,\n        "loadBalancerType": ""\n      },\n      "configConnectorConfig": {\n        "enabled": false\n      },\n      "dnsCacheConfig": {\n        "enabled": false\n      },\n      "gcePersistentDiskCsiDriverConfig": {\n        "enabled": false\n      },\n      "gcpFilestoreCsiDriverConfig": {\n        "enabled": false\n      },\n      "gkeBackupAgentConfig": {\n        "enabled": false\n      },\n      "horizontalPodAutoscaling": {\n        "disabled": false\n      },\n      "httpLoadBalancing": {\n        "disabled": false\n      },\n      "istioConfig": {\n        "auth": "",\n        "disabled": false\n      },\n      "kalmConfig": {\n        "enabled": false\n      },\n      "kubernetesDashboard": {\n        "disabled": false\n      },\n      "networkPolicyConfig": {\n        "disabled": false\n      }\n    },\n    "desiredAuthenticatorGroupsConfig": {\n      "enabled": false,\n      "securityGroup": ""\n    },\n    "desiredBinaryAuthorization": {\n      "enabled": false,\n      "evaluationMode": ""\n    },\n    "desiredClusterAutoscaling": {\n      "autoprovisioningLocations": [],\n      "autoprovisioningNodePoolDefaults": {\n        "bootDiskKmsKey": "",\n        "diskSizeGb": 0,\n        "diskType": "",\n        "imageType": "",\n        "management": {\n          "autoRepair": false,\n          "autoUpgrade": false,\n          "upgradeOptions": {\n            "autoUpgradeStartTime": "",\n            "description": ""\n          }\n        },\n        "minCpuPlatform": "",\n        "oauthScopes": [],\n        "serviceAccount": "",\n        "shieldedInstanceConfig": {\n          "enableIntegrityMonitoring": false,\n          "enableSecureBoot": false\n        },\n        "upgradeSettings": {\n          "blueGreenSettings": {\n            "nodePoolSoakDuration": "",\n            "standardRolloutPolicy": {\n              "batchNodeCount": 0,\n              "batchPercentage": "",\n              "batchSoakDuration": ""\n            }\n          },\n          "maxSurge": 0,\n          "maxUnavailable": 0,\n          "strategy": ""\n        }\n      },\n      "autoscalingProfile": "",\n      "enableNodeAutoprovisioning": false,\n      "resourceLimits": [\n        {\n          "maximum": "",\n          "minimum": "",\n          "resourceType": ""\n        }\n      ]\n    },\n    "desiredClusterTelemetry": {\n      "type": ""\n    },\n    "desiredCostManagementConfig": {\n      "enabled": false\n    },\n    "desiredDatabaseEncryption": {\n      "keyName": "",\n      "state": ""\n    },\n    "desiredDatapathProvider": "",\n    "desiredDefaultSnatStatus": {\n      "disabled": false\n    },\n    "desiredDnsConfig": {\n      "clusterDns": "",\n      "clusterDnsDomain": "",\n      "clusterDnsScope": ""\n    },\n    "desiredEnablePrivateEndpoint": false,\n    "desiredGatewayApiConfig": {\n      "channel": ""\n    },\n    "desiredGcfsConfig": {\n      "enabled": false\n    },\n    "desiredIdentityServiceConfig": {\n      "enabled": false\n    },\n    "desiredImageType": "",\n    "desiredIntraNodeVisibilityConfig": {\n      "enabled": false\n    },\n    "desiredL4ilbSubsettingConfig": {\n      "enabled": false\n    },\n    "desiredLocations": [],\n    "desiredLoggingConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      }\n    },\n    "desiredLoggingService": "",\n    "desiredMaster": {},\n    "desiredMasterAuthorizedNetworksConfig": {\n      "cidrBlocks": [\n        {\n          "cidrBlock": "",\n          "displayName": ""\n        }\n      ],\n      "enabled": false,\n      "gcpPublicCidrsAccessEnabled": false\n    },\n    "desiredMasterVersion": "",\n    "desiredMeshCertificates": {\n      "enableCertificates": false\n    },\n    "desiredMonitoringConfig": {\n      "componentConfig": {\n        "enableComponents": []\n      },\n      "managedPrometheusConfig": {\n        "enabled": false\n      }\n    },\n    "desiredMonitoringService": "",\n    "desiredNodePoolAutoConfigNetworkTags": {\n      "tags": []\n    },\n    "desiredNodePoolAutoscaling": {\n      "autoprovisioned": false,\n      "enabled": false,\n      "locationPolicy": "",\n      "maxNodeCount": 0,\n      "minNodeCount": 0,\n      "totalMaxNodeCount": 0,\n      "totalMinNodeCount": 0\n    },\n    "desiredNodePoolId": "",\n    "desiredNodePoolLoggingConfig": {\n      "variantConfig": {\n        "variant": ""\n      }\n    },\n    "desiredNodeVersion": "",\n    "desiredNotificationConfig": {\n      "pubsub": {\n        "enabled": false,\n        "filter": {\n          "eventType": []\n        },\n        "topic": ""\n      }\n    },\n    "desiredPodSecurityPolicyConfig": {\n      "enabled": false\n    },\n    "desiredPrivateClusterConfig": {\n      "enablePrivateEndpoint": false,\n      "enablePrivateNodes": false,\n      "masterGlobalAccessConfig": {\n        "enabled": false\n      },\n      "masterIpv4CidrBlock": "",\n      "peeringName": "",\n      "privateEndpoint": "",\n      "privateEndpointSubnetwork": "",\n      "publicEndpoint": ""\n    },\n    "desiredPrivateIpv6GoogleAccess": "",\n    "desiredProtectConfig": {\n      "workloadConfig": {\n        "auditMode": ""\n      },\n      "workloadVulnerabilityMode": ""\n    },\n    "desiredReleaseChannel": {\n      "channel": ""\n    },\n    "desiredResourceUsageExportConfig": {\n      "bigqueryDestination": {\n        "datasetId": ""\n      },\n      "consumptionMeteringConfig": {\n        "enabled": false\n      },\n      "enableNetworkEgressMetering": false\n    },\n    "desiredServiceExternalIpsConfig": {\n      "enabled": false\n    },\n    "desiredShieldedNodes": {\n      "enabled": false\n    },\n    "desiredStackType": "",\n    "desiredTpuConfig": {\n      "enabled": false,\n      "ipv4CidrBlock": "",\n      "useServiceNetworking": false\n    },\n    "desiredVerticalPodAutoscaling": {\n      "enabled": false\n    },\n    "desiredWorkloadAltsConfig": {\n      "enableAlts": false\n    },\n    "desiredWorkloadCertificates": {\n      "enableCertificates": false\n    },\n    "desiredWorkloadIdentityConfig": {\n      "identityNamespace": "",\n      "identityProvider": "",\n      "workloadPool": ""\n    },\n    "etag": "",\n    "removedAdditionalPodRangesConfig": {}\n  },\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "clusterId": "",
  "name": "",
  "projectId": "",
  "update": [
    "additionalPodRangesConfig": ["podRangeNames": []],
    "desiredAddonsConfig": [
      "cloudRunConfig": [
        "disabled": false,
        "loadBalancerType": ""
      ],
      "configConnectorConfig": ["enabled": false],
      "dnsCacheConfig": ["enabled": false],
      "gcePersistentDiskCsiDriverConfig": ["enabled": false],
      "gcpFilestoreCsiDriverConfig": ["enabled": false],
      "gkeBackupAgentConfig": ["enabled": false],
      "horizontalPodAutoscaling": ["disabled": false],
      "httpLoadBalancing": ["disabled": false],
      "istioConfig": [
        "auth": "",
        "disabled": false
      ],
      "kalmConfig": ["enabled": false],
      "kubernetesDashboard": ["disabled": false],
      "networkPolicyConfig": ["disabled": false]
    ],
    "desiredAuthenticatorGroupsConfig": [
      "enabled": false,
      "securityGroup": ""
    ],
    "desiredBinaryAuthorization": [
      "enabled": false,
      "evaluationMode": ""
    ],
    "desiredClusterAutoscaling": [
      "autoprovisioningLocations": [],
      "autoprovisioningNodePoolDefaults": [
        "bootDiskKmsKey": "",
        "diskSizeGb": 0,
        "diskType": "",
        "imageType": "",
        "management": [
          "autoRepair": false,
          "autoUpgrade": false,
          "upgradeOptions": [
            "autoUpgradeStartTime": "",
            "description": ""
          ]
        ],
        "minCpuPlatform": "",
        "oauthScopes": [],
        "serviceAccount": "",
        "shieldedInstanceConfig": [
          "enableIntegrityMonitoring": false,
          "enableSecureBoot": false
        ],
        "upgradeSettings": [
          "blueGreenSettings": [
            "nodePoolSoakDuration": "",
            "standardRolloutPolicy": [
              "batchNodeCount": 0,
              "batchPercentage": "",
              "batchSoakDuration": ""
            ]
          ],
          "maxSurge": 0,
          "maxUnavailable": 0,
          "strategy": ""
        ]
      ],
      "autoscalingProfile": "",
      "enableNodeAutoprovisioning": false,
      "resourceLimits": [
        [
          "maximum": "",
          "minimum": "",
          "resourceType": ""
        ]
      ]
    ],
    "desiredClusterTelemetry": ["type": ""],
    "desiredCostManagementConfig": ["enabled": false],
    "desiredDatabaseEncryption": [
      "keyName": "",
      "state": ""
    ],
    "desiredDatapathProvider": "",
    "desiredDefaultSnatStatus": ["disabled": false],
    "desiredDnsConfig": [
      "clusterDns": "",
      "clusterDnsDomain": "",
      "clusterDnsScope": ""
    ],
    "desiredEnablePrivateEndpoint": false,
    "desiredGatewayApiConfig": ["channel": ""],
    "desiredGcfsConfig": ["enabled": false],
    "desiredIdentityServiceConfig": ["enabled": false],
    "desiredImageType": "",
    "desiredIntraNodeVisibilityConfig": ["enabled": false],
    "desiredL4ilbSubsettingConfig": ["enabled": false],
    "desiredLocations": [],
    "desiredLoggingConfig": ["componentConfig": ["enableComponents": []]],
    "desiredLoggingService": "",
    "desiredMaster": [],
    "desiredMasterAuthorizedNetworksConfig": [
      "cidrBlocks": [
        [
          "cidrBlock": "",
          "displayName": ""
        ]
      ],
      "enabled": false,
      "gcpPublicCidrsAccessEnabled": false
    ],
    "desiredMasterVersion": "",
    "desiredMeshCertificates": ["enableCertificates": false],
    "desiredMonitoringConfig": [
      "componentConfig": ["enableComponents": []],
      "managedPrometheusConfig": ["enabled": false]
    ],
    "desiredMonitoringService": "",
    "desiredNodePoolAutoConfigNetworkTags": ["tags": []],
    "desiredNodePoolAutoscaling": [
      "autoprovisioned": false,
      "enabled": false,
      "locationPolicy": "",
      "maxNodeCount": 0,
      "minNodeCount": 0,
      "totalMaxNodeCount": 0,
      "totalMinNodeCount": 0
    ],
    "desiredNodePoolId": "",
    "desiredNodePoolLoggingConfig": ["variantConfig": ["variant": ""]],
    "desiredNodeVersion": "",
    "desiredNotificationConfig": ["pubsub": [
        "enabled": false,
        "filter": ["eventType": []],
        "topic": ""
      ]],
    "desiredPodSecurityPolicyConfig": ["enabled": false],
    "desiredPrivateClusterConfig": [
      "enablePrivateEndpoint": false,
      "enablePrivateNodes": false,
      "masterGlobalAccessConfig": ["enabled": false],
      "masterIpv4CidrBlock": "",
      "peeringName": "",
      "privateEndpoint": "",
      "privateEndpointSubnetwork": "",
      "publicEndpoint": ""
    ],
    "desiredPrivateIpv6GoogleAccess": "",
    "desiredProtectConfig": [
      "workloadConfig": ["auditMode": ""],
      "workloadVulnerabilityMode": ""
    ],
    "desiredReleaseChannel": ["channel": ""],
    "desiredResourceUsageExportConfig": [
      "bigqueryDestination": ["datasetId": ""],
      "consumptionMeteringConfig": ["enabled": false],
      "enableNetworkEgressMetering": false
    ],
    "desiredServiceExternalIpsConfig": ["enabled": false],
    "desiredShieldedNodes": ["enabled": false],
    "desiredStackType": "",
    "desiredTpuConfig": [
      "enabled": false,
      "ipv4CidrBlock": "",
      "useServiceNetworking": false
    ],
    "desiredVerticalPodAutoscaling": ["enabled": false],
    "desiredWorkloadAltsConfig": ["enableAlts": false],
    "desiredWorkloadCertificates": ["enableCertificates": false],
    "desiredWorkloadIdentityConfig": [
      "identityNamespace": "",
      "identityProvider": "",
      "workloadPool": ""
    ],
    "etag": "",
    "removedAdditionalPodRangesConfig": []
  ],
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/clusters/:clusterId")! 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 container.projects.zones.getServerconfig
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig
QUERY PARAMS

projectId
zone
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig")
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig"

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}}/v1beta1/projects/:projectId/zones/:zone/serverconfig"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig"

	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/v1beta1/projects/:projectId/zones/:zone/serverconfig HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig"))
    .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}}/v1beta1/projects/:projectId/zones/:zone/serverconfig")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig")
  .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}}/v1beta1/projects/:projectId/zones/:zone/serverconfig');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig';
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}}/v1beta1/projects/:projectId/zones/:zone/serverconfig',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/projects/:projectId/zones/:zone/serverconfig',
  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}}/v1beta1/projects/:projectId/zones/:zone/serverconfig'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig');

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}}/v1beta1/projects/:projectId/zones/:zone/serverconfig'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig';
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}}/v1beta1/projects/:projectId/zones/:zone/serverconfig"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/serverconfig" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig",
  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}}/v1beta1/projects/:projectId/zones/:zone/serverconfig');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/serverconfig")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig")

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/v1beta1/projects/:projectId/zones/:zone/serverconfig') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig";

    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}}/v1beta1/projects/:projectId/zones/:zone/serverconfig
http GET {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/serverconfig")! 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 container.projects.zones.operations.cancel
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel
QUERY PARAMS

projectId
zone
operationId
BODY json

{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel" {:content-type :json
                                                                                                                   :form-params {:name ""
                                                                                                                                 :operationId ""
                                                                                                                                 :projectId ""
                                                                                                                                 :zone ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel"),
    Content = new StringContent("{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel"

	payload := strings.NewReader("{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 70

{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel")
  .header("content-type", "application/json")
  .body("{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  name: '',
  operationId: '',
  projectId: '',
  zone: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel',
  headers: {'content-type': 'application/json'},
  data: {name: '', operationId: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","operationId":"","projectId":"","zone":""}'
};

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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "name": "",\n  "operationId": "",\n  "projectId": "",\n  "zone": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({name: '', operationId: '', projectId: '', zone: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel',
  headers: {'content-type': 'application/json'},
  body: {name: '', operationId: '', projectId: '', zone: ''},
  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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  name: '',
  operationId: '',
  projectId: '',
  zone: ''
});

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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel',
  headers: {'content-type': 'application/json'},
  data: {name: '', operationId: '', projectId: '', zone: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"name":"","operationId":"","projectId":"","zone":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"name": @"",
                              @"operationId": @"",
                              @"projectId": @"",
                              @"zone": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'name' => '',
    'operationId' => '',
    'projectId' => '',
    'zone' => ''
  ]),
  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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel', [
  'body' => '{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'name' => '',
  'operationId' => '',
  'projectId' => '',
  'zone' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'name' => '',
  'operationId' => '',
  'projectId' => '',
  'zone' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel"

payload = {
    "name": "",
    "operationId": "",
    "projectId": "",
    "zone": ""
}
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel"

payload <- "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\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/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel') do |req|
  req.body = "{\n  \"name\": \"\",\n  \"operationId\": \"\",\n  \"projectId\": \"\",\n  \"zone\": \"\"\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel";

    let payload = json!({
        "name": "",
        "operationId": "",
        "projectId": "",
        "zone": ""
    });

    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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel \
  --header 'content-type: application/json' \
  --data '{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}'
echo '{
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "name": "",\n  "operationId": "",\n  "projectId": "",\n  "zone": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "name": "",
  "operationId": "",
  "projectId": "",
  "zone": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId:cancel")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET container.projects.zones.operations.get
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId
QUERY PARAMS

projectId
zone
operationId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId")
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId"

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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId"

	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/v1beta1/projects/:projectId/zones/:zone/operations/:operationId HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId"))
    .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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId")
  .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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId';
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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/projects/:projectId/zones/:zone/operations/:operationId',
  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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId');

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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId';
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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId"]
                                                       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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId",
  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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/operations/:operationId")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId")

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/v1beta1/projects/:projectId/zones/:zone/operations/:operationId') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId";

    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}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId
http GET {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations/:operationId")! 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 container.projects.zones.operations.list
{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations
QUERY PARAMS

projectId
zone
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations")
require "http/client"

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/v1beta1/projects/:projectId/zones/:zone/operations HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/projects/:projectId/zones/:zone/operations',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations'
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'GET',
  url: '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations'
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/projects/:projectId/zones/:zone/operations")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/v1beta1/projects/:projectId/zones/:zone/operations') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations
http GET {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/projects/:projectId/zones/:zone/operations")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()