GET lifesciences.projects.locations.list
{{baseUrl}}/v2beta/:name/locations
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

func main() {

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

url = "{{baseUrl}}/v2beta/:name/locations"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta/:name/locations"

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

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

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

puts response.status
puts response.body
use reqwest;

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta/:name/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 lifesciences.projects.locations.operations.cancel
{{baseUrl}}/v2beta/:name:cancel
QUERY PARAMS

name
BODY json

{}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

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

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

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

func main() {

	url := "{{baseUrl}}/v2beta/:name:cancel"

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

curl_close($curl);

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

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

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

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

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

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

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

payload = "{}"

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

conn.request("POST", "/baseUrl/v2beta/:name:cancel", payload, headers)

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

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

url = "{{baseUrl}}/v2beta/:name:cancel"

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

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

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

url <- "{{baseUrl}}/v2beta/:name:cancel"

payload <- "{}"

encode <- "json"

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

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

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

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

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

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

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

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

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

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

    let payload = json!({});

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

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

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta/: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 lifesciences.projects.locations.operations.get
{{baseUrl}}/v2beta/: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}}/v2beta/:name");

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

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

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

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

func main() {

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

response = requests.get(url)

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta/: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 lifesciences.projects.locations.operations.list
{{baseUrl}}/v2beta/:name/operations
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

url = "{{baseUrl}}/v2beta/:name/operations"

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

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

func main() {

	url := "{{baseUrl}}/v2beta/:name/operations"

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

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

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

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

}
GET /baseUrl/v2beta/:name/operations HTTP/1.1
Host: example.com

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

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

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

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

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

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

xhr.open('GET', '{{baseUrl}}/v2beta/:name/operations');

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

const url = '{{baseUrl}}/v2beta/:name/operations';
const options = {method: 'GET'};

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

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

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

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

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

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

curl_close($curl);

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

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

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

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

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

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

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

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

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

url = "{{baseUrl}}/v2beta/:name/operations"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta/:name/operations"

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

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

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

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

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

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

dataTask.resume()
POST lifesciences.projects.locations.pipelines.run
{{baseUrl}}/v2beta/:parent/pipelines:run
QUERY PARAMS

parent
BODY json

{
  "labels": {},
  "pipeline": {
    "actions": [
      {
        "alwaysRun": false,
        "blockExternalNetwork": false,
        "commands": [],
        "containerName": "",
        "credentials": {
          "cipherText": "",
          "keyName": ""
        },
        "disableImagePrefetch": false,
        "disableStandardErrorCapture": false,
        "enableFuse": false,
        "encryptedEnvironment": {},
        "entrypoint": "",
        "environment": {},
        "ignoreExitStatus": false,
        "imageUri": "",
        "labels": {},
        "mounts": [
          {
            "disk": "",
            "path": "",
            "readOnly": false
          }
        ],
        "pidNamespace": "",
        "portMappings": {},
        "publishExposedPorts": false,
        "runInBackground": false,
        "timeout": ""
      }
    ],
    "encryptedEnvironment": {},
    "environment": {},
    "resources": {
      "regions": [],
      "virtualMachine": {
        "accelerators": [
          {
            "count": "",
            "type": ""
          }
        ],
        "bootDiskSizeGb": 0,
        "bootImage": "",
        "cpuPlatform": "",
        "disks": [
          {
            "name": "",
            "sizeGb": 0,
            "sourceImage": "",
            "type": ""
          }
        ],
        "dockerCacheImages": [],
        "enableStackdriverMonitoring": false,
        "labels": {},
        "machineType": "",
        "network": {
          "network": "",
          "subnetwork": "",
          "usePrivateAddress": false
        },
        "nvidiaDriverVersion": "",
        "preemptible": false,
        "reservation": "",
        "serviceAccount": {
          "email": "",
          "scopes": []
        },
        "volumes": [
          {
            "existingDisk": {
              "disk": ""
            },
            "nfsMount": {
              "target": ""
            },
            "persistentDisk": {
              "sizeGb": 0,
              "sourceImage": "",
              "type": ""
            },
            "volume": ""
          }
        ]
      },
      "zones": []
    },
    "timeout": ""
  },
  "pubSubTopic": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta/:parent/pipelines:run");

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  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\n}");

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

(client/post "{{baseUrl}}/v2beta/:parent/pipelines:run" {:content-type :json
                                                                         :form-params {:labels {}
                                                                                       :pipeline {:actions [{:alwaysRun false
                                                                                                             :blockExternalNetwork false
                                                                                                             :commands []
                                                                                                             :containerName ""
                                                                                                             :credentials {:cipherText ""
                                                                                                                           :keyName ""}
                                                                                                             :disableImagePrefetch false
                                                                                                             :disableStandardErrorCapture false
                                                                                                             :enableFuse false
                                                                                                             :encryptedEnvironment {}
                                                                                                             :entrypoint ""
                                                                                                             :environment {}
                                                                                                             :ignoreExitStatus false
                                                                                                             :imageUri ""
                                                                                                             :labels {}
                                                                                                             :mounts [{:disk ""
                                                                                                                       :path ""
                                                                                                                       :readOnly false}]
                                                                                                             :pidNamespace ""
                                                                                                             :portMappings {}
                                                                                                             :publishExposedPorts false
                                                                                                             :runInBackground false
                                                                                                             :timeout ""}]
                                                                                                  :encryptedEnvironment {}
                                                                                                  :environment {}
                                                                                                  :resources {:regions []
                                                                                                              :virtualMachine {:accelerators [{:count ""
                                                                                                                                               :type ""}]
                                                                                                                               :bootDiskSizeGb 0
                                                                                                                               :bootImage ""
                                                                                                                               :cpuPlatform ""
                                                                                                                               :disks [{:name ""
                                                                                                                                        :sizeGb 0
                                                                                                                                        :sourceImage ""
                                                                                                                                        :type ""}]
                                                                                                                               :dockerCacheImages []
                                                                                                                               :enableStackdriverMonitoring false
                                                                                                                               :labels {}
                                                                                                                               :machineType ""
                                                                                                                               :network {:network ""
                                                                                                                                         :subnetwork ""
                                                                                                                                         :usePrivateAddress false}
                                                                                                                               :nvidiaDriverVersion ""
                                                                                                                               :preemptible false
                                                                                                                               :reservation ""
                                                                                                                               :serviceAccount {:email ""
                                                                                                                                                :scopes []}
                                                                                                                               :volumes [{:existingDisk {:disk ""}
                                                                                                                                          :nfsMount {:target ""}
                                                                                                                                          :persistentDisk {:sizeGb 0
                                                                                                                                                           :sourceImage ""
                                                                                                                                                           :type ""}
                                                                                                                                          :volume ""}]}
                                                                                                              :zones []}
                                                                                                  :timeout ""}
                                                                                       :pubSubTopic ""}})
require "http/client"

url = "{{baseUrl}}/v2beta/:parent/pipelines:run"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\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}}/v2beta/:parent/pipelines:run"),
    Content = new StringContent("{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\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}}/v2beta/:parent/pipelines:run");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta/:parent/pipelines:run"

	payload := strings.NewReader("{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\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/v2beta/:parent/pipelines:run HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2172

{
  "labels": {},
  "pipeline": {
    "actions": [
      {
        "alwaysRun": false,
        "blockExternalNetwork": false,
        "commands": [],
        "containerName": "",
        "credentials": {
          "cipherText": "",
          "keyName": ""
        },
        "disableImagePrefetch": false,
        "disableStandardErrorCapture": false,
        "enableFuse": false,
        "encryptedEnvironment": {},
        "entrypoint": "",
        "environment": {},
        "ignoreExitStatus": false,
        "imageUri": "",
        "labels": {},
        "mounts": [
          {
            "disk": "",
            "path": "",
            "readOnly": false
          }
        ],
        "pidNamespace": "",
        "portMappings": {},
        "publishExposedPorts": false,
        "runInBackground": false,
        "timeout": ""
      }
    ],
    "encryptedEnvironment": {},
    "environment": {},
    "resources": {
      "regions": [],
      "virtualMachine": {
        "accelerators": [
          {
            "count": "",
            "type": ""
          }
        ],
        "bootDiskSizeGb": 0,
        "bootImage": "",
        "cpuPlatform": "",
        "disks": [
          {
            "name": "",
            "sizeGb": 0,
            "sourceImage": "",
            "type": ""
          }
        ],
        "dockerCacheImages": [],
        "enableStackdriverMonitoring": false,
        "labels": {},
        "machineType": "",
        "network": {
          "network": "",
          "subnetwork": "",
          "usePrivateAddress": false
        },
        "nvidiaDriverVersion": "",
        "preemptible": false,
        "reservation": "",
        "serviceAccount": {
          "email": "",
          "scopes": []
        },
        "volumes": [
          {
            "existingDisk": {
              "disk": ""
            },
            "nfsMount": {
              "target": ""
            },
            "persistentDisk": {
              "sizeGb": 0,
              "sourceImage": "",
              "type": ""
            },
            "volume": ""
          }
        ]
      },
      "zones": []
    },
    "timeout": ""
  },
  "pubSubTopic": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta/:parent/pipelines:run")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta/:parent/pipelines:run"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\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  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta/:parent/pipelines:run")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta/:parent/pipelines:run")
  .header("content-type", "application/json")
  .body("{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  labels: {},
  pipeline: {
    actions: [
      {
        alwaysRun: false,
        blockExternalNetwork: false,
        commands: [],
        containerName: '',
        credentials: {
          cipherText: '',
          keyName: ''
        },
        disableImagePrefetch: false,
        disableStandardErrorCapture: false,
        enableFuse: false,
        encryptedEnvironment: {},
        entrypoint: '',
        environment: {},
        ignoreExitStatus: false,
        imageUri: '',
        labels: {},
        mounts: [
          {
            disk: '',
            path: '',
            readOnly: false
          }
        ],
        pidNamespace: '',
        portMappings: {},
        publishExposedPorts: false,
        runInBackground: false,
        timeout: ''
      }
    ],
    encryptedEnvironment: {},
    environment: {},
    resources: {
      regions: [],
      virtualMachine: {
        accelerators: [
          {
            count: '',
            type: ''
          }
        ],
        bootDiskSizeGb: 0,
        bootImage: '',
        cpuPlatform: '',
        disks: [
          {
            name: '',
            sizeGb: 0,
            sourceImage: '',
            type: ''
          }
        ],
        dockerCacheImages: [],
        enableStackdriverMonitoring: false,
        labels: {},
        machineType: '',
        network: {
          network: '',
          subnetwork: '',
          usePrivateAddress: false
        },
        nvidiaDriverVersion: '',
        preemptible: false,
        reservation: '',
        serviceAccount: {
          email: '',
          scopes: []
        },
        volumes: [
          {
            existingDisk: {
              disk: ''
            },
            nfsMount: {
              target: ''
            },
            persistentDisk: {
              sizeGb: 0,
              sourceImage: '',
              type: ''
            },
            volume: ''
          }
        ]
      },
      zones: []
    },
    timeout: ''
  },
  pubSubTopic: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta/:parent/pipelines:run',
  headers: {'content-type': 'application/json'},
  data: {
    labels: {},
    pipeline: {
      actions: [
        {
          alwaysRun: false,
          blockExternalNetwork: false,
          commands: [],
          containerName: '',
          credentials: {cipherText: '', keyName: ''},
          disableImagePrefetch: false,
          disableStandardErrorCapture: false,
          enableFuse: false,
          encryptedEnvironment: {},
          entrypoint: '',
          environment: {},
          ignoreExitStatus: false,
          imageUri: '',
          labels: {},
          mounts: [{disk: '', path: '', readOnly: false}],
          pidNamespace: '',
          portMappings: {},
          publishExposedPorts: false,
          runInBackground: false,
          timeout: ''
        }
      ],
      encryptedEnvironment: {},
      environment: {},
      resources: {
        regions: [],
        virtualMachine: {
          accelerators: [{count: '', type: ''}],
          bootDiskSizeGb: 0,
          bootImage: '',
          cpuPlatform: '',
          disks: [{name: '', sizeGb: 0, sourceImage: '', type: ''}],
          dockerCacheImages: [],
          enableStackdriverMonitoring: false,
          labels: {},
          machineType: '',
          network: {network: '', subnetwork: '', usePrivateAddress: false},
          nvidiaDriverVersion: '',
          preemptible: false,
          reservation: '',
          serviceAccount: {email: '', scopes: []},
          volumes: [
            {
              existingDisk: {disk: ''},
              nfsMount: {target: ''},
              persistentDisk: {sizeGb: 0, sourceImage: '', type: ''},
              volume: ''
            }
          ]
        },
        zones: []
      },
      timeout: ''
    },
    pubSubTopic: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta/:parent/pipelines:run';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"labels":{},"pipeline":{"actions":[{"alwaysRun":false,"blockExternalNetwork":false,"commands":[],"containerName":"","credentials":{"cipherText":"","keyName":""},"disableImagePrefetch":false,"disableStandardErrorCapture":false,"enableFuse":false,"encryptedEnvironment":{},"entrypoint":"","environment":{},"ignoreExitStatus":false,"imageUri":"","labels":{},"mounts":[{"disk":"","path":"","readOnly":false}],"pidNamespace":"","portMappings":{},"publishExposedPorts":false,"runInBackground":false,"timeout":""}],"encryptedEnvironment":{},"environment":{},"resources":{"regions":[],"virtualMachine":{"accelerators":[{"count":"","type":""}],"bootDiskSizeGb":0,"bootImage":"","cpuPlatform":"","disks":[{"name":"","sizeGb":0,"sourceImage":"","type":""}],"dockerCacheImages":[],"enableStackdriverMonitoring":false,"labels":{},"machineType":"","network":{"network":"","subnetwork":"","usePrivateAddress":false},"nvidiaDriverVersion":"","preemptible":false,"reservation":"","serviceAccount":{"email":"","scopes":[]},"volumes":[{"existingDisk":{"disk":""},"nfsMount":{"target":""},"persistentDisk":{"sizeGb":0,"sourceImage":"","type":""},"volume":""}]},"zones":[]},"timeout":""},"pubSubTopic":""}'
};

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}}/v2beta/:parent/pipelines:run',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "labels": {},\n  "pipeline": {\n    "actions": [\n      {\n        "alwaysRun": false,\n        "blockExternalNetwork": false,\n        "commands": [],\n        "containerName": "",\n        "credentials": {\n          "cipherText": "",\n          "keyName": ""\n        },\n        "disableImagePrefetch": false,\n        "disableStandardErrorCapture": false,\n        "enableFuse": false,\n        "encryptedEnvironment": {},\n        "entrypoint": "",\n        "environment": {},\n        "ignoreExitStatus": false,\n        "imageUri": "",\n        "labels": {},\n        "mounts": [\n          {\n            "disk": "",\n            "path": "",\n            "readOnly": false\n          }\n        ],\n        "pidNamespace": "",\n        "portMappings": {},\n        "publishExposedPorts": false,\n        "runInBackground": false,\n        "timeout": ""\n      }\n    ],\n    "encryptedEnvironment": {},\n    "environment": {},\n    "resources": {\n      "regions": [],\n      "virtualMachine": {\n        "accelerators": [\n          {\n            "count": "",\n            "type": ""\n          }\n        ],\n        "bootDiskSizeGb": 0,\n        "bootImage": "",\n        "cpuPlatform": "",\n        "disks": [\n          {\n            "name": "",\n            "sizeGb": 0,\n            "sourceImage": "",\n            "type": ""\n          }\n        ],\n        "dockerCacheImages": [],\n        "enableStackdriverMonitoring": false,\n        "labels": {},\n        "machineType": "",\n        "network": {\n          "network": "",\n          "subnetwork": "",\n          "usePrivateAddress": false\n        },\n        "nvidiaDriverVersion": "",\n        "preemptible": false,\n        "reservation": "",\n        "serviceAccount": {\n          "email": "",\n          "scopes": []\n        },\n        "volumes": [\n          {\n            "existingDisk": {\n              "disk": ""\n            },\n            "nfsMount": {\n              "target": ""\n            },\n            "persistentDisk": {\n              "sizeGb": 0,\n              "sourceImage": "",\n              "type": ""\n            },\n            "volume": ""\n          }\n        ]\n      },\n      "zones": []\n    },\n    "timeout": ""\n  },\n  "pubSubTopic": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta/:parent/pipelines:run")
  .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/v2beta/:parent/pipelines:run',
  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({
  labels: {},
  pipeline: {
    actions: [
      {
        alwaysRun: false,
        blockExternalNetwork: false,
        commands: [],
        containerName: '',
        credentials: {cipherText: '', keyName: ''},
        disableImagePrefetch: false,
        disableStandardErrorCapture: false,
        enableFuse: false,
        encryptedEnvironment: {},
        entrypoint: '',
        environment: {},
        ignoreExitStatus: false,
        imageUri: '',
        labels: {},
        mounts: [{disk: '', path: '', readOnly: false}],
        pidNamespace: '',
        portMappings: {},
        publishExposedPorts: false,
        runInBackground: false,
        timeout: ''
      }
    ],
    encryptedEnvironment: {},
    environment: {},
    resources: {
      regions: [],
      virtualMachine: {
        accelerators: [{count: '', type: ''}],
        bootDiskSizeGb: 0,
        bootImage: '',
        cpuPlatform: '',
        disks: [{name: '', sizeGb: 0, sourceImage: '', type: ''}],
        dockerCacheImages: [],
        enableStackdriverMonitoring: false,
        labels: {},
        machineType: '',
        network: {network: '', subnetwork: '', usePrivateAddress: false},
        nvidiaDriverVersion: '',
        preemptible: false,
        reservation: '',
        serviceAccount: {email: '', scopes: []},
        volumes: [
          {
            existingDisk: {disk: ''},
            nfsMount: {target: ''},
            persistentDisk: {sizeGb: 0, sourceImage: '', type: ''},
            volume: ''
          }
        ]
      },
      zones: []
    },
    timeout: ''
  },
  pubSubTopic: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta/:parent/pipelines:run',
  headers: {'content-type': 'application/json'},
  body: {
    labels: {},
    pipeline: {
      actions: [
        {
          alwaysRun: false,
          blockExternalNetwork: false,
          commands: [],
          containerName: '',
          credentials: {cipherText: '', keyName: ''},
          disableImagePrefetch: false,
          disableStandardErrorCapture: false,
          enableFuse: false,
          encryptedEnvironment: {},
          entrypoint: '',
          environment: {},
          ignoreExitStatus: false,
          imageUri: '',
          labels: {},
          mounts: [{disk: '', path: '', readOnly: false}],
          pidNamespace: '',
          portMappings: {},
          publishExposedPorts: false,
          runInBackground: false,
          timeout: ''
        }
      ],
      encryptedEnvironment: {},
      environment: {},
      resources: {
        regions: [],
        virtualMachine: {
          accelerators: [{count: '', type: ''}],
          bootDiskSizeGb: 0,
          bootImage: '',
          cpuPlatform: '',
          disks: [{name: '', sizeGb: 0, sourceImage: '', type: ''}],
          dockerCacheImages: [],
          enableStackdriverMonitoring: false,
          labels: {},
          machineType: '',
          network: {network: '', subnetwork: '', usePrivateAddress: false},
          nvidiaDriverVersion: '',
          preemptible: false,
          reservation: '',
          serviceAccount: {email: '', scopes: []},
          volumes: [
            {
              existingDisk: {disk: ''},
              nfsMount: {target: ''},
              persistentDisk: {sizeGb: 0, sourceImage: '', type: ''},
              volume: ''
            }
          ]
        },
        zones: []
      },
      timeout: ''
    },
    pubSubTopic: ''
  },
  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}}/v2beta/:parent/pipelines:run');

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

req.type('json');
req.send({
  labels: {},
  pipeline: {
    actions: [
      {
        alwaysRun: false,
        blockExternalNetwork: false,
        commands: [],
        containerName: '',
        credentials: {
          cipherText: '',
          keyName: ''
        },
        disableImagePrefetch: false,
        disableStandardErrorCapture: false,
        enableFuse: false,
        encryptedEnvironment: {},
        entrypoint: '',
        environment: {},
        ignoreExitStatus: false,
        imageUri: '',
        labels: {},
        mounts: [
          {
            disk: '',
            path: '',
            readOnly: false
          }
        ],
        pidNamespace: '',
        portMappings: {},
        publishExposedPorts: false,
        runInBackground: false,
        timeout: ''
      }
    ],
    encryptedEnvironment: {},
    environment: {},
    resources: {
      regions: [],
      virtualMachine: {
        accelerators: [
          {
            count: '',
            type: ''
          }
        ],
        bootDiskSizeGb: 0,
        bootImage: '',
        cpuPlatform: '',
        disks: [
          {
            name: '',
            sizeGb: 0,
            sourceImage: '',
            type: ''
          }
        ],
        dockerCacheImages: [],
        enableStackdriverMonitoring: false,
        labels: {},
        machineType: '',
        network: {
          network: '',
          subnetwork: '',
          usePrivateAddress: false
        },
        nvidiaDriverVersion: '',
        preemptible: false,
        reservation: '',
        serviceAccount: {
          email: '',
          scopes: []
        },
        volumes: [
          {
            existingDisk: {
              disk: ''
            },
            nfsMount: {
              target: ''
            },
            persistentDisk: {
              sizeGb: 0,
              sourceImage: '',
              type: ''
            },
            volume: ''
          }
        ]
      },
      zones: []
    },
    timeout: ''
  },
  pubSubTopic: ''
});

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}}/v2beta/:parent/pipelines:run',
  headers: {'content-type': 'application/json'},
  data: {
    labels: {},
    pipeline: {
      actions: [
        {
          alwaysRun: false,
          blockExternalNetwork: false,
          commands: [],
          containerName: '',
          credentials: {cipherText: '', keyName: ''},
          disableImagePrefetch: false,
          disableStandardErrorCapture: false,
          enableFuse: false,
          encryptedEnvironment: {},
          entrypoint: '',
          environment: {},
          ignoreExitStatus: false,
          imageUri: '',
          labels: {},
          mounts: [{disk: '', path: '', readOnly: false}],
          pidNamespace: '',
          portMappings: {},
          publishExposedPorts: false,
          runInBackground: false,
          timeout: ''
        }
      ],
      encryptedEnvironment: {},
      environment: {},
      resources: {
        regions: [],
        virtualMachine: {
          accelerators: [{count: '', type: ''}],
          bootDiskSizeGb: 0,
          bootImage: '',
          cpuPlatform: '',
          disks: [{name: '', sizeGb: 0, sourceImage: '', type: ''}],
          dockerCacheImages: [],
          enableStackdriverMonitoring: false,
          labels: {},
          machineType: '',
          network: {network: '', subnetwork: '', usePrivateAddress: false},
          nvidiaDriverVersion: '',
          preemptible: false,
          reservation: '',
          serviceAccount: {email: '', scopes: []},
          volumes: [
            {
              existingDisk: {disk: ''},
              nfsMount: {target: ''},
              persistentDisk: {sizeGb: 0, sourceImage: '', type: ''},
              volume: ''
            }
          ]
        },
        zones: []
      },
      timeout: ''
    },
    pubSubTopic: ''
  }
};

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

const url = '{{baseUrl}}/v2beta/:parent/pipelines:run';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"labels":{},"pipeline":{"actions":[{"alwaysRun":false,"blockExternalNetwork":false,"commands":[],"containerName":"","credentials":{"cipherText":"","keyName":""},"disableImagePrefetch":false,"disableStandardErrorCapture":false,"enableFuse":false,"encryptedEnvironment":{},"entrypoint":"","environment":{},"ignoreExitStatus":false,"imageUri":"","labels":{},"mounts":[{"disk":"","path":"","readOnly":false}],"pidNamespace":"","portMappings":{},"publishExposedPorts":false,"runInBackground":false,"timeout":""}],"encryptedEnvironment":{},"environment":{},"resources":{"regions":[],"virtualMachine":{"accelerators":[{"count":"","type":""}],"bootDiskSizeGb":0,"bootImage":"","cpuPlatform":"","disks":[{"name":"","sizeGb":0,"sourceImage":"","type":""}],"dockerCacheImages":[],"enableStackdriverMonitoring":false,"labels":{},"machineType":"","network":{"network":"","subnetwork":"","usePrivateAddress":false},"nvidiaDriverVersion":"","preemptible":false,"reservation":"","serviceAccount":{"email":"","scopes":[]},"volumes":[{"existingDisk":{"disk":""},"nfsMount":{"target":""},"persistentDisk":{"sizeGb":0,"sourceImage":"","type":""},"volume":""}]},"zones":[]},"timeout":""},"pubSubTopic":""}'
};

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 = @{ @"labels": @{  },
                              @"pipeline": @{ @"actions": @[ @{ @"alwaysRun": @NO, @"blockExternalNetwork": @NO, @"commands": @[  ], @"containerName": @"", @"credentials": @{ @"cipherText": @"", @"keyName": @"" }, @"disableImagePrefetch": @NO, @"disableStandardErrorCapture": @NO, @"enableFuse": @NO, @"encryptedEnvironment": @{  }, @"entrypoint": @"", @"environment": @{  }, @"ignoreExitStatus": @NO, @"imageUri": @"", @"labels": @{  }, @"mounts": @[ @{ @"disk": @"", @"path": @"", @"readOnly": @NO } ], @"pidNamespace": @"", @"portMappings": @{  }, @"publishExposedPorts": @NO, @"runInBackground": @NO, @"timeout": @"" } ], @"encryptedEnvironment": @{  }, @"environment": @{  }, @"resources": @{ @"regions": @[  ], @"virtualMachine": @{ @"accelerators": @[ @{ @"count": @"", @"type": @"" } ], @"bootDiskSizeGb": @0, @"bootImage": @"", @"cpuPlatform": @"", @"disks": @[ @{ @"name": @"", @"sizeGb": @0, @"sourceImage": @"", @"type": @"" } ], @"dockerCacheImages": @[  ], @"enableStackdriverMonitoring": @NO, @"labels": @{  }, @"machineType": @"", @"network": @{ @"network": @"", @"subnetwork": @"", @"usePrivateAddress": @NO }, @"nvidiaDriverVersion": @"", @"preemptible": @NO, @"reservation": @"", @"serviceAccount": @{ @"email": @"", @"scopes": @[  ] }, @"volumes": @[ @{ @"existingDisk": @{ @"disk": @"" }, @"nfsMount": @{ @"target": @"" }, @"persistentDisk": @{ @"sizeGb": @0, @"sourceImage": @"", @"type": @"" }, @"volume": @"" } ] }, @"zones": @[  ] }, @"timeout": @"" },
                              @"pubSubTopic": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta/:parent/pipelines:run"]
                                                       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}}/v2beta/:parent/pipelines:run" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta/:parent/pipelines:run",
  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([
    'labels' => [
        
    ],
    'pipeline' => [
        'actions' => [
                [
                                'alwaysRun' => null,
                                'blockExternalNetwork' => null,
                                'commands' => [
                                                                
                                ],
                                'containerName' => '',
                                'credentials' => [
                                                                'cipherText' => '',
                                                                'keyName' => ''
                                ],
                                'disableImagePrefetch' => null,
                                'disableStandardErrorCapture' => null,
                                'enableFuse' => null,
                                'encryptedEnvironment' => [
                                                                
                                ],
                                'entrypoint' => '',
                                'environment' => [
                                                                
                                ],
                                'ignoreExitStatus' => null,
                                'imageUri' => '',
                                'labels' => [
                                                                
                                ],
                                'mounts' => [
                                                                [
                                                                                                                                'disk' => '',
                                                                                                                                'path' => '',
                                                                                                                                'readOnly' => null
                                                                ]
                                ],
                                'pidNamespace' => '',
                                'portMappings' => [
                                                                
                                ],
                                'publishExposedPorts' => null,
                                'runInBackground' => null,
                                'timeout' => ''
                ]
        ],
        'encryptedEnvironment' => [
                
        ],
        'environment' => [
                
        ],
        'resources' => [
                'regions' => [
                                
                ],
                'virtualMachine' => [
                                'accelerators' => [
                                                                [
                                                                                                                                'count' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'bootDiskSizeGb' => 0,
                                'bootImage' => '',
                                'cpuPlatform' => '',
                                'disks' => [
                                                                [
                                                                                                                                'name' => '',
                                                                                                                                'sizeGb' => 0,
                                                                                                                                'sourceImage' => '',
                                                                                                                                'type' => ''
                                                                ]
                                ],
                                'dockerCacheImages' => [
                                                                
                                ],
                                'enableStackdriverMonitoring' => null,
                                'labels' => [
                                                                
                                ],
                                'machineType' => '',
                                'network' => [
                                                                'network' => '',
                                                                'subnetwork' => '',
                                                                'usePrivateAddress' => null
                                ],
                                'nvidiaDriverVersion' => '',
                                'preemptible' => null,
                                'reservation' => '',
                                'serviceAccount' => [
                                                                'email' => '',
                                                                'scopes' => [
                                                                                                                                
                                                                ]
                                ],
                                'volumes' => [
                                                                [
                                                                                                                                'existingDisk' => [
                                                                                                                                                                                                                                                                'disk' => ''
                                                                                                                                ],
                                                                                                                                'nfsMount' => [
                                                                                                                                                                                                                                                                'target' => ''
                                                                                                                                ],
                                                                                                                                'persistentDisk' => [
                                                                                                                                                                                                                                                                'sizeGb' => 0,
                                                                                                                                                                                                                                                                'sourceImage' => '',
                                                                                                                                                                                                                                                                'type' => ''
                                                                                                                                ],
                                                                                                                                'volume' => ''
                                                                ]
                                ]
                ],
                'zones' => [
                                
                ]
        ],
        'timeout' => ''
    ],
    'pubSubTopic' => ''
  ]),
  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}}/v2beta/:parent/pipelines:run', [
  'body' => '{
  "labels": {},
  "pipeline": {
    "actions": [
      {
        "alwaysRun": false,
        "blockExternalNetwork": false,
        "commands": [],
        "containerName": "",
        "credentials": {
          "cipherText": "",
          "keyName": ""
        },
        "disableImagePrefetch": false,
        "disableStandardErrorCapture": false,
        "enableFuse": false,
        "encryptedEnvironment": {},
        "entrypoint": "",
        "environment": {},
        "ignoreExitStatus": false,
        "imageUri": "",
        "labels": {},
        "mounts": [
          {
            "disk": "",
            "path": "",
            "readOnly": false
          }
        ],
        "pidNamespace": "",
        "portMappings": {},
        "publishExposedPorts": false,
        "runInBackground": false,
        "timeout": ""
      }
    ],
    "encryptedEnvironment": {},
    "environment": {},
    "resources": {
      "regions": [],
      "virtualMachine": {
        "accelerators": [
          {
            "count": "",
            "type": ""
          }
        ],
        "bootDiskSizeGb": 0,
        "bootImage": "",
        "cpuPlatform": "",
        "disks": [
          {
            "name": "",
            "sizeGb": 0,
            "sourceImage": "",
            "type": ""
          }
        ],
        "dockerCacheImages": [],
        "enableStackdriverMonitoring": false,
        "labels": {},
        "machineType": "",
        "network": {
          "network": "",
          "subnetwork": "",
          "usePrivateAddress": false
        },
        "nvidiaDriverVersion": "",
        "preemptible": false,
        "reservation": "",
        "serviceAccount": {
          "email": "",
          "scopes": []
        },
        "volumes": [
          {
            "existingDisk": {
              "disk": ""
            },
            "nfsMount": {
              "target": ""
            },
            "persistentDisk": {
              "sizeGb": 0,
              "sourceImage": "",
              "type": ""
            },
            "volume": ""
          }
        ]
      },
      "zones": []
    },
    "timeout": ""
  },
  "pubSubTopic": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'labels' => [
    
  ],
  'pipeline' => [
    'actions' => [
        [
                'alwaysRun' => null,
                'blockExternalNetwork' => null,
                'commands' => [
                                
                ],
                'containerName' => '',
                'credentials' => [
                                'cipherText' => '',
                                'keyName' => ''
                ],
                'disableImagePrefetch' => null,
                'disableStandardErrorCapture' => null,
                'enableFuse' => null,
                'encryptedEnvironment' => [
                                
                ],
                'entrypoint' => '',
                'environment' => [
                                
                ],
                'ignoreExitStatus' => null,
                'imageUri' => '',
                'labels' => [
                                
                ],
                'mounts' => [
                                [
                                                                'disk' => '',
                                                                'path' => '',
                                                                'readOnly' => null
                                ]
                ],
                'pidNamespace' => '',
                'portMappings' => [
                                
                ],
                'publishExposedPorts' => null,
                'runInBackground' => null,
                'timeout' => ''
        ]
    ],
    'encryptedEnvironment' => [
        
    ],
    'environment' => [
        
    ],
    'resources' => [
        'regions' => [
                
        ],
        'virtualMachine' => [
                'accelerators' => [
                                [
                                                                'count' => '',
                                                                'type' => ''
                                ]
                ],
                'bootDiskSizeGb' => 0,
                'bootImage' => '',
                'cpuPlatform' => '',
                'disks' => [
                                [
                                                                'name' => '',
                                                                'sizeGb' => 0,
                                                                'sourceImage' => '',
                                                                'type' => ''
                                ]
                ],
                'dockerCacheImages' => [
                                
                ],
                'enableStackdriverMonitoring' => null,
                'labels' => [
                                
                ],
                'machineType' => '',
                'network' => [
                                'network' => '',
                                'subnetwork' => '',
                                'usePrivateAddress' => null
                ],
                'nvidiaDriverVersion' => '',
                'preemptible' => null,
                'reservation' => '',
                'serviceAccount' => [
                                'email' => '',
                                'scopes' => [
                                                                
                                ]
                ],
                'volumes' => [
                                [
                                                                'existingDisk' => [
                                                                                                                                'disk' => ''
                                                                ],
                                                                'nfsMount' => [
                                                                                                                                'target' => ''
                                                                ],
                                                                'persistentDisk' => [
                                                                                                                                'sizeGb' => 0,
                                                                                                                                'sourceImage' => '',
                                                                                                                                'type' => ''
                                                                ],
                                                                'volume' => ''
                                ]
                ]
        ],
        'zones' => [
                
        ]
    ],
    'timeout' => ''
  ],
  'pubSubTopic' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'labels' => [
    
  ],
  'pipeline' => [
    'actions' => [
        [
                'alwaysRun' => null,
                'blockExternalNetwork' => null,
                'commands' => [
                                
                ],
                'containerName' => '',
                'credentials' => [
                                'cipherText' => '',
                                'keyName' => ''
                ],
                'disableImagePrefetch' => null,
                'disableStandardErrorCapture' => null,
                'enableFuse' => null,
                'encryptedEnvironment' => [
                                
                ],
                'entrypoint' => '',
                'environment' => [
                                
                ],
                'ignoreExitStatus' => null,
                'imageUri' => '',
                'labels' => [
                                
                ],
                'mounts' => [
                                [
                                                                'disk' => '',
                                                                'path' => '',
                                                                'readOnly' => null
                                ]
                ],
                'pidNamespace' => '',
                'portMappings' => [
                                
                ],
                'publishExposedPorts' => null,
                'runInBackground' => null,
                'timeout' => ''
        ]
    ],
    'encryptedEnvironment' => [
        
    ],
    'environment' => [
        
    ],
    'resources' => [
        'regions' => [
                
        ],
        'virtualMachine' => [
                'accelerators' => [
                                [
                                                                'count' => '',
                                                                'type' => ''
                                ]
                ],
                'bootDiskSizeGb' => 0,
                'bootImage' => '',
                'cpuPlatform' => '',
                'disks' => [
                                [
                                                                'name' => '',
                                                                'sizeGb' => 0,
                                                                'sourceImage' => '',
                                                                'type' => ''
                                ]
                ],
                'dockerCacheImages' => [
                                
                ],
                'enableStackdriverMonitoring' => null,
                'labels' => [
                                
                ],
                'machineType' => '',
                'network' => [
                                'network' => '',
                                'subnetwork' => '',
                                'usePrivateAddress' => null
                ],
                'nvidiaDriverVersion' => '',
                'preemptible' => null,
                'reservation' => '',
                'serviceAccount' => [
                                'email' => '',
                                'scopes' => [
                                                                
                                ]
                ],
                'volumes' => [
                                [
                                                                'existingDisk' => [
                                                                                                                                'disk' => ''
                                                                ],
                                                                'nfsMount' => [
                                                                                                                                'target' => ''
                                                                ],
                                                                'persistentDisk' => [
                                                                                                                                'sizeGb' => 0,
                                                                                                                                'sourceImage' => '',
                                                                                                                                'type' => ''
                                                                ],
                                                                'volume' => ''
                                ]
                ]
        ],
        'zones' => [
                
        ]
    ],
    'timeout' => ''
  ],
  'pubSubTopic' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v2beta/:parent/pipelines:run');
$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}}/v2beta/:parent/pipelines:run' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "labels": {},
  "pipeline": {
    "actions": [
      {
        "alwaysRun": false,
        "blockExternalNetwork": false,
        "commands": [],
        "containerName": "",
        "credentials": {
          "cipherText": "",
          "keyName": ""
        },
        "disableImagePrefetch": false,
        "disableStandardErrorCapture": false,
        "enableFuse": false,
        "encryptedEnvironment": {},
        "entrypoint": "",
        "environment": {},
        "ignoreExitStatus": false,
        "imageUri": "",
        "labels": {},
        "mounts": [
          {
            "disk": "",
            "path": "",
            "readOnly": false
          }
        ],
        "pidNamespace": "",
        "portMappings": {},
        "publishExposedPorts": false,
        "runInBackground": false,
        "timeout": ""
      }
    ],
    "encryptedEnvironment": {},
    "environment": {},
    "resources": {
      "regions": [],
      "virtualMachine": {
        "accelerators": [
          {
            "count": "",
            "type": ""
          }
        ],
        "bootDiskSizeGb": 0,
        "bootImage": "",
        "cpuPlatform": "",
        "disks": [
          {
            "name": "",
            "sizeGb": 0,
            "sourceImage": "",
            "type": ""
          }
        ],
        "dockerCacheImages": [],
        "enableStackdriverMonitoring": false,
        "labels": {},
        "machineType": "",
        "network": {
          "network": "",
          "subnetwork": "",
          "usePrivateAddress": false
        },
        "nvidiaDriverVersion": "",
        "preemptible": false,
        "reservation": "",
        "serviceAccount": {
          "email": "",
          "scopes": []
        },
        "volumes": [
          {
            "existingDisk": {
              "disk": ""
            },
            "nfsMount": {
              "target": ""
            },
            "persistentDisk": {
              "sizeGb": 0,
              "sourceImage": "",
              "type": ""
            },
            "volume": ""
          }
        ]
      },
      "zones": []
    },
    "timeout": ""
  },
  "pubSubTopic": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta/:parent/pipelines:run' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "labels": {},
  "pipeline": {
    "actions": [
      {
        "alwaysRun": false,
        "blockExternalNetwork": false,
        "commands": [],
        "containerName": "",
        "credentials": {
          "cipherText": "",
          "keyName": ""
        },
        "disableImagePrefetch": false,
        "disableStandardErrorCapture": false,
        "enableFuse": false,
        "encryptedEnvironment": {},
        "entrypoint": "",
        "environment": {},
        "ignoreExitStatus": false,
        "imageUri": "",
        "labels": {},
        "mounts": [
          {
            "disk": "",
            "path": "",
            "readOnly": false
          }
        ],
        "pidNamespace": "",
        "portMappings": {},
        "publishExposedPorts": false,
        "runInBackground": false,
        "timeout": ""
      }
    ],
    "encryptedEnvironment": {},
    "environment": {},
    "resources": {
      "regions": [],
      "virtualMachine": {
        "accelerators": [
          {
            "count": "",
            "type": ""
          }
        ],
        "bootDiskSizeGb": 0,
        "bootImage": "",
        "cpuPlatform": "",
        "disks": [
          {
            "name": "",
            "sizeGb": 0,
            "sourceImage": "",
            "type": ""
          }
        ],
        "dockerCacheImages": [],
        "enableStackdriverMonitoring": false,
        "labels": {},
        "machineType": "",
        "network": {
          "network": "",
          "subnetwork": "",
          "usePrivateAddress": false
        },
        "nvidiaDriverVersion": "",
        "preemptible": false,
        "reservation": "",
        "serviceAccount": {
          "email": "",
          "scopes": []
        },
        "volumes": [
          {
            "existingDisk": {
              "disk": ""
            },
            "nfsMount": {
              "target": ""
            },
            "persistentDisk": {
              "sizeGb": 0,
              "sourceImage": "",
              "type": ""
            },
            "volume": ""
          }
        ]
      },
      "zones": []
    },
    "timeout": ""
  },
  "pubSubTopic": ""
}'
import http.client

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

payload = "{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v2beta/:parent/pipelines:run", payload, headers)

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

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

url = "{{baseUrl}}/v2beta/:parent/pipelines:run"

payload = {
    "labels": {},
    "pipeline": {
        "actions": [
            {
                "alwaysRun": False,
                "blockExternalNetwork": False,
                "commands": [],
                "containerName": "",
                "credentials": {
                    "cipherText": "",
                    "keyName": ""
                },
                "disableImagePrefetch": False,
                "disableStandardErrorCapture": False,
                "enableFuse": False,
                "encryptedEnvironment": {},
                "entrypoint": "",
                "environment": {},
                "ignoreExitStatus": False,
                "imageUri": "",
                "labels": {},
                "mounts": [
                    {
                        "disk": "",
                        "path": "",
                        "readOnly": False
                    }
                ],
                "pidNamespace": "",
                "portMappings": {},
                "publishExposedPorts": False,
                "runInBackground": False,
                "timeout": ""
            }
        ],
        "encryptedEnvironment": {},
        "environment": {},
        "resources": {
            "regions": [],
            "virtualMachine": {
                "accelerators": [
                    {
                        "count": "",
                        "type": ""
                    }
                ],
                "bootDiskSizeGb": 0,
                "bootImage": "",
                "cpuPlatform": "",
                "disks": [
                    {
                        "name": "",
                        "sizeGb": 0,
                        "sourceImage": "",
                        "type": ""
                    }
                ],
                "dockerCacheImages": [],
                "enableStackdriverMonitoring": False,
                "labels": {},
                "machineType": "",
                "network": {
                    "network": "",
                    "subnetwork": "",
                    "usePrivateAddress": False
                },
                "nvidiaDriverVersion": "",
                "preemptible": False,
                "reservation": "",
                "serviceAccount": {
                    "email": "",
                    "scopes": []
                },
                "volumes": [
                    {
                        "existingDisk": { "disk": "" },
                        "nfsMount": { "target": "" },
                        "persistentDisk": {
                            "sizeGb": 0,
                            "sourceImage": "",
                            "type": ""
                        },
                        "volume": ""
                    }
                ]
            },
            "zones": []
        },
        "timeout": ""
    },
    "pubSubTopic": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta/:parent/pipelines:run"

payload <- "{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\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}}/v2beta/:parent/pipelines:run")

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  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\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/v2beta/:parent/pipelines:run') do |req|
  req.body = "{\n  \"labels\": {},\n  \"pipeline\": {\n    \"actions\": [\n      {\n        \"alwaysRun\": false,\n        \"blockExternalNetwork\": false,\n        \"commands\": [],\n        \"containerName\": \"\",\n        \"credentials\": {\n          \"cipherText\": \"\",\n          \"keyName\": \"\"\n        },\n        \"disableImagePrefetch\": false,\n        \"disableStandardErrorCapture\": false,\n        \"enableFuse\": false,\n        \"encryptedEnvironment\": {},\n        \"entrypoint\": \"\",\n        \"environment\": {},\n        \"ignoreExitStatus\": false,\n        \"imageUri\": \"\",\n        \"labels\": {},\n        \"mounts\": [\n          {\n            \"disk\": \"\",\n            \"path\": \"\",\n            \"readOnly\": false\n          }\n        ],\n        \"pidNamespace\": \"\",\n        \"portMappings\": {},\n        \"publishExposedPorts\": false,\n        \"runInBackground\": false,\n        \"timeout\": \"\"\n      }\n    ],\n    \"encryptedEnvironment\": {},\n    \"environment\": {},\n    \"resources\": {\n      \"regions\": [],\n      \"virtualMachine\": {\n        \"accelerators\": [\n          {\n            \"count\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"bootDiskSizeGb\": 0,\n        \"bootImage\": \"\",\n        \"cpuPlatform\": \"\",\n        \"disks\": [\n          {\n            \"name\": \"\",\n            \"sizeGb\": 0,\n            \"sourceImage\": \"\",\n            \"type\": \"\"\n          }\n        ],\n        \"dockerCacheImages\": [],\n        \"enableStackdriverMonitoring\": false,\n        \"labels\": {},\n        \"machineType\": \"\",\n        \"network\": {\n          \"network\": \"\",\n          \"subnetwork\": \"\",\n          \"usePrivateAddress\": false\n        },\n        \"nvidiaDriverVersion\": \"\",\n        \"preemptible\": false,\n        \"reservation\": \"\",\n        \"serviceAccount\": {\n          \"email\": \"\",\n          \"scopes\": []\n        },\n        \"volumes\": [\n          {\n            \"existingDisk\": {\n              \"disk\": \"\"\n            },\n            \"nfsMount\": {\n              \"target\": \"\"\n            },\n            \"persistentDisk\": {\n              \"sizeGb\": 0,\n              \"sourceImage\": \"\",\n              \"type\": \"\"\n            },\n            \"volume\": \"\"\n          }\n        ]\n      },\n      \"zones\": []\n    },\n    \"timeout\": \"\"\n  },\n  \"pubSubTopic\": \"\"\n}"
end

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

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

    let payload = json!({
        "labels": json!({}),
        "pipeline": json!({
            "actions": (
                json!({
                    "alwaysRun": false,
                    "blockExternalNetwork": false,
                    "commands": (),
                    "containerName": "",
                    "credentials": json!({
                        "cipherText": "",
                        "keyName": ""
                    }),
                    "disableImagePrefetch": false,
                    "disableStandardErrorCapture": false,
                    "enableFuse": false,
                    "encryptedEnvironment": json!({}),
                    "entrypoint": "",
                    "environment": json!({}),
                    "ignoreExitStatus": false,
                    "imageUri": "",
                    "labels": json!({}),
                    "mounts": (
                        json!({
                            "disk": "",
                            "path": "",
                            "readOnly": false
                        })
                    ),
                    "pidNamespace": "",
                    "portMappings": json!({}),
                    "publishExposedPorts": false,
                    "runInBackground": false,
                    "timeout": ""
                })
            ),
            "encryptedEnvironment": json!({}),
            "environment": json!({}),
            "resources": json!({
                "regions": (),
                "virtualMachine": json!({
                    "accelerators": (
                        json!({
                            "count": "",
                            "type": ""
                        })
                    ),
                    "bootDiskSizeGb": 0,
                    "bootImage": "",
                    "cpuPlatform": "",
                    "disks": (
                        json!({
                            "name": "",
                            "sizeGb": 0,
                            "sourceImage": "",
                            "type": ""
                        })
                    ),
                    "dockerCacheImages": (),
                    "enableStackdriverMonitoring": false,
                    "labels": json!({}),
                    "machineType": "",
                    "network": json!({
                        "network": "",
                        "subnetwork": "",
                        "usePrivateAddress": false
                    }),
                    "nvidiaDriverVersion": "",
                    "preemptible": false,
                    "reservation": "",
                    "serviceAccount": json!({
                        "email": "",
                        "scopes": ()
                    }),
                    "volumes": (
                        json!({
                            "existingDisk": json!({"disk": ""}),
                            "nfsMount": json!({"target": ""}),
                            "persistentDisk": json!({
                                "sizeGb": 0,
                                "sourceImage": "",
                                "type": ""
                            }),
                            "volume": ""
                        })
                    )
                }),
                "zones": ()
            }),
            "timeout": ""
        }),
        "pubSubTopic": ""
    });

    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}}/v2beta/:parent/pipelines:run \
  --header 'content-type: application/json' \
  --data '{
  "labels": {},
  "pipeline": {
    "actions": [
      {
        "alwaysRun": false,
        "blockExternalNetwork": false,
        "commands": [],
        "containerName": "",
        "credentials": {
          "cipherText": "",
          "keyName": ""
        },
        "disableImagePrefetch": false,
        "disableStandardErrorCapture": false,
        "enableFuse": false,
        "encryptedEnvironment": {},
        "entrypoint": "",
        "environment": {},
        "ignoreExitStatus": false,
        "imageUri": "",
        "labels": {},
        "mounts": [
          {
            "disk": "",
            "path": "",
            "readOnly": false
          }
        ],
        "pidNamespace": "",
        "portMappings": {},
        "publishExposedPorts": false,
        "runInBackground": false,
        "timeout": ""
      }
    ],
    "encryptedEnvironment": {},
    "environment": {},
    "resources": {
      "regions": [],
      "virtualMachine": {
        "accelerators": [
          {
            "count": "",
            "type": ""
          }
        ],
        "bootDiskSizeGb": 0,
        "bootImage": "",
        "cpuPlatform": "",
        "disks": [
          {
            "name": "",
            "sizeGb": 0,
            "sourceImage": "",
            "type": ""
          }
        ],
        "dockerCacheImages": [],
        "enableStackdriverMonitoring": false,
        "labels": {},
        "machineType": "",
        "network": {
          "network": "",
          "subnetwork": "",
          "usePrivateAddress": false
        },
        "nvidiaDriverVersion": "",
        "preemptible": false,
        "reservation": "",
        "serviceAccount": {
          "email": "",
          "scopes": []
        },
        "volumes": [
          {
            "existingDisk": {
              "disk": ""
            },
            "nfsMount": {
              "target": ""
            },
            "persistentDisk": {
              "sizeGb": 0,
              "sourceImage": "",
              "type": ""
            },
            "volume": ""
          }
        ]
      },
      "zones": []
    },
    "timeout": ""
  },
  "pubSubTopic": ""
}'
echo '{
  "labels": {},
  "pipeline": {
    "actions": [
      {
        "alwaysRun": false,
        "blockExternalNetwork": false,
        "commands": [],
        "containerName": "",
        "credentials": {
          "cipherText": "",
          "keyName": ""
        },
        "disableImagePrefetch": false,
        "disableStandardErrorCapture": false,
        "enableFuse": false,
        "encryptedEnvironment": {},
        "entrypoint": "",
        "environment": {},
        "ignoreExitStatus": false,
        "imageUri": "",
        "labels": {},
        "mounts": [
          {
            "disk": "",
            "path": "",
            "readOnly": false
          }
        ],
        "pidNamespace": "",
        "portMappings": {},
        "publishExposedPorts": false,
        "runInBackground": false,
        "timeout": ""
      }
    ],
    "encryptedEnvironment": {},
    "environment": {},
    "resources": {
      "regions": [],
      "virtualMachine": {
        "accelerators": [
          {
            "count": "",
            "type": ""
          }
        ],
        "bootDiskSizeGb": 0,
        "bootImage": "",
        "cpuPlatform": "",
        "disks": [
          {
            "name": "",
            "sizeGb": 0,
            "sourceImage": "",
            "type": ""
          }
        ],
        "dockerCacheImages": [],
        "enableStackdriverMonitoring": false,
        "labels": {},
        "machineType": "",
        "network": {
          "network": "",
          "subnetwork": "",
          "usePrivateAddress": false
        },
        "nvidiaDriverVersion": "",
        "preemptible": false,
        "reservation": "",
        "serviceAccount": {
          "email": "",
          "scopes": []
        },
        "volumes": [
          {
            "existingDisk": {
              "disk": ""
            },
            "nfsMount": {
              "target": ""
            },
            "persistentDisk": {
              "sizeGb": 0,
              "sourceImage": "",
              "type": ""
            },
            "volume": ""
          }
        ]
      },
      "zones": []
    },
    "timeout": ""
  },
  "pubSubTopic": ""
}' |  \
  http POST {{baseUrl}}/v2beta/:parent/pipelines:run \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "labels": {},\n  "pipeline": {\n    "actions": [\n      {\n        "alwaysRun": false,\n        "blockExternalNetwork": false,\n        "commands": [],\n        "containerName": "",\n        "credentials": {\n          "cipherText": "",\n          "keyName": ""\n        },\n        "disableImagePrefetch": false,\n        "disableStandardErrorCapture": false,\n        "enableFuse": false,\n        "encryptedEnvironment": {},\n        "entrypoint": "",\n        "environment": {},\n        "ignoreExitStatus": false,\n        "imageUri": "",\n        "labels": {},\n        "mounts": [\n          {\n            "disk": "",\n            "path": "",\n            "readOnly": false\n          }\n        ],\n        "pidNamespace": "",\n        "portMappings": {},\n        "publishExposedPorts": false,\n        "runInBackground": false,\n        "timeout": ""\n      }\n    ],\n    "encryptedEnvironment": {},\n    "environment": {},\n    "resources": {\n      "regions": [],\n      "virtualMachine": {\n        "accelerators": [\n          {\n            "count": "",\n            "type": ""\n          }\n        ],\n        "bootDiskSizeGb": 0,\n        "bootImage": "",\n        "cpuPlatform": "",\n        "disks": [\n          {\n            "name": "",\n            "sizeGb": 0,\n            "sourceImage": "",\n            "type": ""\n          }\n        ],\n        "dockerCacheImages": [],\n        "enableStackdriverMonitoring": false,\n        "labels": {},\n        "machineType": "",\n        "network": {\n          "network": "",\n          "subnetwork": "",\n          "usePrivateAddress": false\n        },\n        "nvidiaDriverVersion": "",\n        "preemptible": false,\n        "reservation": "",\n        "serviceAccount": {\n          "email": "",\n          "scopes": []\n        },\n        "volumes": [\n          {\n            "existingDisk": {\n              "disk": ""\n            },\n            "nfsMount": {\n              "target": ""\n            },\n            "persistentDisk": {\n              "sizeGb": 0,\n              "sourceImage": "",\n              "type": ""\n            },\n            "volume": ""\n          }\n        ]\n      },\n      "zones": []\n    },\n    "timeout": ""\n  },\n  "pubSubTopic": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta/:parent/pipelines:run
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "labels": [],
  "pipeline": [
    "actions": [
      [
        "alwaysRun": false,
        "blockExternalNetwork": false,
        "commands": [],
        "containerName": "",
        "credentials": [
          "cipherText": "",
          "keyName": ""
        ],
        "disableImagePrefetch": false,
        "disableStandardErrorCapture": false,
        "enableFuse": false,
        "encryptedEnvironment": [],
        "entrypoint": "",
        "environment": [],
        "ignoreExitStatus": false,
        "imageUri": "",
        "labels": [],
        "mounts": [
          [
            "disk": "",
            "path": "",
            "readOnly": false
          ]
        ],
        "pidNamespace": "",
        "portMappings": [],
        "publishExposedPorts": false,
        "runInBackground": false,
        "timeout": ""
      ]
    ],
    "encryptedEnvironment": [],
    "environment": [],
    "resources": [
      "regions": [],
      "virtualMachine": [
        "accelerators": [
          [
            "count": "",
            "type": ""
          ]
        ],
        "bootDiskSizeGb": 0,
        "bootImage": "",
        "cpuPlatform": "",
        "disks": [
          [
            "name": "",
            "sizeGb": 0,
            "sourceImage": "",
            "type": ""
          ]
        ],
        "dockerCacheImages": [],
        "enableStackdriverMonitoring": false,
        "labels": [],
        "machineType": "",
        "network": [
          "network": "",
          "subnetwork": "",
          "usePrivateAddress": false
        ],
        "nvidiaDriverVersion": "",
        "preemptible": false,
        "reservation": "",
        "serviceAccount": [
          "email": "",
          "scopes": []
        ],
        "volumes": [
          [
            "existingDisk": ["disk": ""],
            "nfsMount": ["target": ""],
            "persistentDisk": [
              "sizeGb": 0,
              "sourceImage": "",
              "type": ""
            ],
            "volume": ""
          ]
        ]
      ],
      "zones": []
    ],
    "timeout": ""
  ],
  "pubSubTopic": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta/:parent/pipelines:run")! 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()