GET cloudtasks.projects.locations.list
{{baseUrl}}/v2beta3/: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}}/v2beta3/:name/locations");

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

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

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

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

func main() {

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

response = requests.get(url)

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta3/: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 cloudtasks.projects.locations.queues.create
{{baseUrl}}/v2beta3/:parent/queues
QUERY PARAMS

parent
BODY json

{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}");

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

(client/post "{{baseUrl}}/v2beta3/:parent/queues" {:content-type :json
                                                                   :form-params {:appEngineHttpQueue {:appEngineRoutingOverride {:host ""
                                                                                                                                 :instance ""
                                                                                                                                 :service ""
                                                                                                                                 :version ""}}
                                                                                 :httpTarget {:headerOverrides [{:header {:key ""
                                                                                                                          :value ""}}]
                                                                                              :httpMethod ""
                                                                                              :uriOverride {:host ""
                                                                                                            :pathOverride {:path ""}
                                                                                                            :port ""
                                                                                                            :queryOverride {:queryParams ""}
                                                                                                            :scheme ""
                                                                                                            :uriOverrideEnforceMode ""}}
                                                                                 :name ""
                                                                                 :purgeTime ""
                                                                                 :rateLimits {:maxBurstSize 0
                                                                                              :maxConcurrentDispatches 0
                                                                                              :maxDispatchesPerSecond ""}
                                                                                 :retryConfig {:maxAttempts 0
                                                                                               :maxBackoff ""
                                                                                               :maxDoublings 0
                                                                                               :maxRetryDuration ""
                                                                                               :minBackoff ""}
                                                                                 :stackdriverLoggingConfig {:samplingRatio ""}
                                                                                 :state ""
                                                                                 :stats {:concurrentDispatchesCount ""
                                                                                         :effectiveExecutionRate ""
                                                                                         :executedLastMinuteCount ""
                                                                                         :oldestEstimatedArrivalTime ""
                                                                                         :tasksCount ""}
                                                                                 :taskTtl ""
                                                                                 :tombstoneTtl ""
                                                                                 :type ""}})
require "http/client"

url = "{{baseUrl}}/v2beta3/:parent/queues"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\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}}/v2beta3/:parent/queues"),
    Content = new StringContent("{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\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}}/v2beta3/:parent/queues");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta3/:parent/queues"

	payload := strings.NewReader("{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\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/v2beta3/:parent/queues HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1148

{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta3/:parent/queues")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta3/:parent/queues"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\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  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta3/:parent/queues")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta3/:parent/queues")
  .header("content-type", "application/json")
  .body("{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  appEngineHttpQueue: {
    appEngineRoutingOverride: {
      host: '',
      instance: '',
      service: '',
      version: ''
    }
  },
  httpTarget: {
    headerOverrides: [
      {
        header: {
          key: '',
          value: ''
        }
      }
    ],
    httpMethod: '',
    uriOverride: {
      host: '',
      pathOverride: {
        path: ''
      },
      port: '',
      queryOverride: {
        queryParams: ''
      },
      scheme: '',
      uriOverrideEnforceMode: ''
    }
  },
  name: '',
  purgeTime: '',
  rateLimits: {
    maxBurstSize: 0,
    maxConcurrentDispatches: 0,
    maxDispatchesPerSecond: ''
  },
  retryConfig: {
    maxAttempts: 0,
    maxBackoff: '',
    maxDoublings: 0,
    maxRetryDuration: '',
    minBackoff: ''
  },
  stackdriverLoggingConfig: {
    samplingRatio: ''
  },
  state: '',
  stats: {
    concurrentDispatchesCount: '',
    effectiveExecutionRate: '',
    executedLastMinuteCount: '',
    oldestEstimatedArrivalTime: '',
    tasksCount: ''
  },
  taskTtl: '',
  tombstoneTtl: '',
  type: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:parent/queues',
  headers: {'content-type': 'application/json'},
  data: {
    appEngineHttpQueue: {appEngineRoutingOverride: {host: '', instance: '', service: '', version: ''}},
    httpTarget: {
      headerOverrides: [{header: {key: '', value: ''}}],
      httpMethod: '',
      uriOverride: {
        host: '',
        pathOverride: {path: ''},
        port: '',
        queryOverride: {queryParams: ''},
        scheme: '',
        uriOverrideEnforceMode: ''
      }
    },
    name: '',
    purgeTime: '',
    rateLimits: {maxBurstSize: 0, maxConcurrentDispatches: 0, maxDispatchesPerSecond: ''},
    retryConfig: {
      maxAttempts: 0,
      maxBackoff: '',
      maxDoublings: 0,
      maxRetryDuration: '',
      minBackoff: ''
    },
    stackdriverLoggingConfig: {samplingRatio: ''},
    state: '',
    stats: {
      concurrentDispatchesCount: '',
      effectiveExecutionRate: '',
      executedLastMinuteCount: '',
      oldestEstimatedArrivalTime: '',
      tasksCount: ''
    },
    taskTtl: '',
    tombstoneTtl: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta3/:parent/queues';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appEngineHttpQueue":{"appEngineRoutingOverride":{"host":"","instance":"","service":"","version":""}},"httpTarget":{"headerOverrides":[{"header":{"key":"","value":""}}],"httpMethod":"","uriOverride":{"host":"","pathOverride":{"path":""},"port":"","queryOverride":{"queryParams":""},"scheme":"","uriOverrideEnforceMode":""}},"name":"","purgeTime":"","rateLimits":{"maxBurstSize":0,"maxConcurrentDispatches":0,"maxDispatchesPerSecond":""},"retryConfig":{"maxAttempts":0,"maxBackoff":"","maxDoublings":0,"maxRetryDuration":"","minBackoff":""},"stackdriverLoggingConfig":{"samplingRatio":""},"state":"","stats":{"concurrentDispatchesCount":"","effectiveExecutionRate":"","executedLastMinuteCount":"","oldestEstimatedArrivalTime":"","tasksCount":""},"taskTtl":"","tombstoneTtl":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta3/:parent/queues',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "appEngineHttpQueue": {\n    "appEngineRoutingOverride": {\n      "host": "",\n      "instance": "",\n      "service": "",\n      "version": ""\n    }\n  },\n  "httpTarget": {\n    "headerOverrides": [\n      {\n        "header": {\n          "key": "",\n          "value": ""\n        }\n      }\n    ],\n    "httpMethod": "",\n    "uriOverride": {\n      "host": "",\n      "pathOverride": {\n        "path": ""\n      },\n      "port": "",\n      "queryOverride": {\n        "queryParams": ""\n      },\n      "scheme": "",\n      "uriOverrideEnforceMode": ""\n    }\n  },\n  "name": "",\n  "purgeTime": "",\n  "rateLimits": {\n    "maxBurstSize": 0,\n    "maxConcurrentDispatches": 0,\n    "maxDispatchesPerSecond": ""\n  },\n  "retryConfig": {\n    "maxAttempts": 0,\n    "maxBackoff": "",\n    "maxDoublings": 0,\n    "maxRetryDuration": "",\n    "minBackoff": ""\n  },\n  "stackdriverLoggingConfig": {\n    "samplingRatio": ""\n  },\n  "state": "",\n  "stats": {\n    "concurrentDispatchesCount": "",\n    "effectiveExecutionRate": "",\n    "executedLastMinuteCount": "",\n    "oldestEstimatedArrivalTime": "",\n    "tasksCount": ""\n  },\n  "taskTtl": "",\n  "tombstoneTtl": "",\n  "type": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta3/:parent/queues")
  .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/v2beta3/:parent/queues',
  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({
  appEngineHttpQueue: {appEngineRoutingOverride: {host: '', instance: '', service: '', version: ''}},
  httpTarget: {
    headerOverrides: [{header: {key: '', value: ''}}],
    httpMethod: '',
    uriOverride: {
      host: '',
      pathOverride: {path: ''},
      port: '',
      queryOverride: {queryParams: ''},
      scheme: '',
      uriOverrideEnforceMode: ''
    }
  },
  name: '',
  purgeTime: '',
  rateLimits: {maxBurstSize: 0, maxConcurrentDispatches: 0, maxDispatchesPerSecond: ''},
  retryConfig: {
    maxAttempts: 0,
    maxBackoff: '',
    maxDoublings: 0,
    maxRetryDuration: '',
    minBackoff: ''
  },
  stackdriverLoggingConfig: {samplingRatio: ''},
  state: '',
  stats: {
    concurrentDispatchesCount: '',
    effectiveExecutionRate: '',
    executedLastMinuteCount: '',
    oldestEstimatedArrivalTime: '',
    tasksCount: ''
  },
  taskTtl: '',
  tombstoneTtl: '',
  type: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:parent/queues',
  headers: {'content-type': 'application/json'},
  body: {
    appEngineHttpQueue: {appEngineRoutingOverride: {host: '', instance: '', service: '', version: ''}},
    httpTarget: {
      headerOverrides: [{header: {key: '', value: ''}}],
      httpMethod: '',
      uriOverride: {
        host: '',
        pathOverride: {path: ''},
        port: '',
        queryOverride: {queryParams: ''},
        scheme: '',
        uriOverrideEnforceMode: ''
      }
    },
    name: '',
    purgeTime: '',
    rateLimits: {maxBurstSize: 0, maxConcurrentDispatches: 0, maxDispatchesPerSecond: ''},
    retryConfig: {
      maxAttempts: 0,
      maxBackoff: '',
      maxDoublings: 0,
      maxRetryDuration: '',
      minBackoff: ''
    },
    stackdriverLoggingConfig: {samplingRatio: ''},
    state: '',
    stats: {
      concurrentDispatchesCount: '',
      effectiveExecutionRate: '',
      executedLastMinuteCount: '',
      oldestEstimatedArrivalTime: '',
      tasksCount: ''
    },
    taskTtl: '',
    tombstoneTtl: '',
    type: ''
  },
  json: true
};

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

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

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

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

req.type('json');
req.send({
  appEngineHttpQueue: {
    appEngineRoutingOverride: {
      host: '',
      instance: '',
      service: '',
      version: ''
    }
  },
  httpTarget: {
    headerOverrides: [
      {
        header: {
          key: '',
          value: ''
        }
      }
    ],
    httpMethod: '',
    uriOverride: {
      host: '',
      pathOverride: {
        path: ''
      },
      port: '',
      queryOverride: {
        queryParams: ''
      },
      scheme: '',
      uriOverrideEnforceMode: ''
    }
  },
  name: '',
  purgeTime: '',
  rateLimits: {
    maxBurstSize: 0,
    maxConcurrentDispatches: 0,
    maxDispatchesPerSecond: ''
  },
  retryConfig: {
    maxAttempts: 0,
    maxBackoff: '',
    maxDoublings: 0,
    maxRetryDuration: '',
    minBackoff: ''
  },
  stackdriverLoggingConfig: {
    samplingRatio: ''
  },
  state: '',
  stats: {
    concurrentDispatchesCount: '',
    effectiveExecutionRate: '',
    executedLastMinuteCount: '',
    oldestEstimatedArrivalTime: '',
    tasksCount: ''
  },
  taskTtl: '',
  tombstoneTtl: '',
  type: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:parent/queues',
  headers: {'content-type': 'application/json'},
  data: {
    appEngineHttpQueue: {appEngineRoutingOverride: {host: '', instance: '', service: '', version: ''}},
    httpTarget: {
      headerOverrides: [{header: {key: '', value: ''}}],
      httpMethod: '',
      uriOverride: {
        host: '',
        pathOverride: {path: ''},
        port: '',
        queryOverride: {queryParams: ''},
        scheme: '',
        uriOverrideEnforceMode: ''
      }
    },
    name: '',
    purgeTime: '',
    rateLimits: {maxBurstSize: 0, maxConcurrentDispatches: 0, maxDispatchesPerSecond: ''},
    retryConfig: {
      maxAttempts: 0,
      maxBackoff: '',
      maxDoublings: 0,
      maxRetryDuration: '',
      minBackoff: ''
    },
    stackdriverLoggingConfig: {samplingRatio: ''},
    state: '',
    stats: {
      concurrentDispatchesCount: '',
      effectiveExecutionRate: '',
      executedLastMinuteCount: '',
      oldestEstimatedArrivalTime: '',
      tasksCount: ''
    },
    taskTtl: '',
    tombstoneTtl: '',
    type: ''
  }
};

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

const url = '{{baseUrl}}/v2beta3/:parent/queues';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appEngineHttpQueue":{"appEngineRoutingOverride":{"host":"","instance":"","service":"","version":""}},"httpTarget":{"headerOverrides":[{"header":{"key":"","value":""}}],"httpMethod":"","uriOverride":{"host":"","pathOverride":{"path":""},"port":"","queryOverride":{"queryParams":""},"scheme":"","uriOverrideEnforceMode":""}},"name":"","purgeTime":"","rateLimits":{"maxBurstSize":0,"maxConcurrentDispatches":0,"maxDispatchesPerSecond":""},"retryConfig":{"maxAttempts":0,"maxBackoff":"","maxDoublings":0,"maxRetryDuration":"","minBackoff":""},"stackdriverLoggingConfig":{"samplingRatio":""},"state":"","stats":{"concurrentDispatchesCount":"","effectiveExecutionRate":"","executedLastMinuteCount":"","oldestEstimatedArrivalTime":"","tasksCount":""},"taskTtl":"","tombstoneTtl":"","type":""}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"appEngineHttpQueue": @{ @"appEngineRoutingOverride": @{ @"host": @"", @"instance": @"", @"service": @"", @"version": @"" } },
                              @"httpTarget": @{ @"headerOverrides": @[ @{ @"header": @{ @"key": @"", @"value": @"" } } ], @"httpMethod": @"", @"uriOverride": @{ @"host": @"", @"pathOverride": @{ @"path": @"" }, @"port": @"", @"queryOverride": @{ @"queryParams": @"" }, @"scheme": @"", @"uriOverrideEnforceMode": @"" } },
                              @"name": @"",
                              @"purgeTime": @"",
                              @"rateLimits": @{ @"maxBurstSize": @0, @"maxConcurrentDispatches": @0, @"maxDispatchesPerSecond": @"" },
                              @"retryConfig": @{ @"maxAttempts": @0, @"maxBackoff": @"", @"maxDoublings": @0, @"maxRetryDuration": @"", @"minBackoff": @"" },
                              @"stackdriverLoggingConfig": @{ @"samplingRatio": @"" },
                              @"state": @"",
                              @"stats": @{ @"concurrentDispatchesCount": @"", @"effectiveExecutionRate": @"", @"executedLastMinuteCount": @"", @"oldestEstimatedArrivalTime": @"", @"tasksCount": @"" },
                              @"taskTtl": @"",
                              @"tombstoneTtl": @"",
                              @"type": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta3/:parent/queues"]
                                                       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}}/v2beta3/:parent/queues" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta3/:parent/queues",
  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([
    'appEngineHttpQueue' => [
        'appEngineRoutingOverride' => [
                'host' => '',
                'instance' => '',
                'service' => '',
                'version' => ''
        ]
    ],
    'httpTarget' => [
        'headerOverrides' => [
                [
                                'header' => [
                                                                'key' => '',
                                                                'value' => ''
                                ]
                ]
        ],
        'httpMethod' => '',
        'uriOverride' => [
                'host' => '',
                'pathOverride' => [
                                'path' => ''
                ],
                'port' => '',
                'queryOverride' => [
                                'queryParams' => ''
                ],
                'scheme' => '',
                'uriOverrideEnforceMode' => ''
        ]
    ],
    'name' => '',
    'purgeTime' => '',
    'rateLimits' => [
        'maxBurstSize' => 0,
        'maxConcurrentDispatches' => 0,
        'maxDispatchesPerSecond' => ''
    ],
    'retryConfig' => [
        'maxAttempts' => 0,
        'maxBackoff' => '',
        'maxDoublings' => 0,
        'maxRetryDuration' => '',
        'minBackoff' => ''
    ],
    'stackdriverLoggingConfig' => [
        'samplingRatio' => ''
    ],
    'state' => '',
    'stats' => [
        'concurrentDispatchesCount' => '',
        'effectiveExecutionRate' => '',
        'executedLastMinuteCount' => '',
        'oldestEstimatedArrivalTime' => '',
        'tasksCount' => ''
    ],
    'taskTtl' => '',
    'tombstoneTtl' => '',
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v2beta3/:parent/queues', [
  'body' => '{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'appEngineHttpQueue' => [
    'appEngineRoutingOverride' => [
        'host' => '',
        'instance' => '',
        'service' => '',
        'version' => ''
    ]
  ],
  'httpTarget' => [
    'headerOverrides' => [
        [
                'header' => [
                                'key' => '',
                                'value' => ''
                ]
        ]
    ],
    'httpMethod' => '',
    'uriOverride' => [
        'host' => '',
        'pathOverride' => [
                'path' => ''
        ],
        'port' => '',
        'queryOverride' => [
                'queryParams' => ''
        ],
        'scheme' => '',
        'uriOverrideEnforceMode' => ''
    ]
  ],
  'name' => '',
  'purgeTime' => '',
  'rateLimits' => [
    'maxBurstSize' => 0,
    'maxConcurrentDispatches' => 0,
    'maxDispatchesPerSecond' => ''
  ],
  'retryConfig' => [
    'maxAttempts' => 0,
    'maxBackoff' => '',
    'maxDoublings' => 0,
    'maxRetryDuration' => '',
    'minBackoff' => ''
  ],
  'stackdriverLoggingConfig' => [
    'samplingRatio' => ''
  ],
  'state' => '',
  'stats' => [
    'concurrentDispatchesCount' => '',
    'effectiveExecutionRate' => '',
    'executedLastMinuteCount' => '',
    'oldestEstimatedArrivalTime' => '',
    'tasksCount' => ''
  ],
  'taskTtl' => '',
  'tombstoneTtl' => '',
  'type' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'appEngineHttpQueue' => [
    'appEngineRoutingOverride' => [
        'host' => '',
        'instance' => '',
        'service' => '',
        'version' => ''
    ]
  ],
  'httpTarget' => [
    'headerOverrides' => [
        [
                'header' => [
                                'key' => '',
                                'value' => ''
                ]
        ]
    ],
    'httpMethod' => '',
    'uriOverride' => [
        'host' => '',
        'pathOverride' => [
                'path' => ''
        ],
        'port' => '',
        'queryOverride' => [
                'queryParams' => ''
        ],
        'scheme' => '',
        'uriOverrideEnforceMode' => ''
    ]
  ],
  'name' => '',
  'purgeTime' => '',
  'rateLimits' => [
    'maxBurstSize' => 0,
    'maxConcurrentDispatches' => 0,
    'maxDispatchesPerSecond' => ''
  ],
  'retryConfig' => [
    'maxAttempts' => 0,
    'maxBackoff' => '',
    'maxDoublings' => 0,
    'maxRetryDuration' => '',
    'minBackoff' => ''
  ],
  'stackdriverLoggingConfig' => [
    'samplingRatio' => ''
  ],
  'state' => '',
  'stats' => [
    'concurrentDispatchesCount' => '',
    'effectiveExecutionRate' => '',
    'executedLastMinuteCount' => '',
    'oldestEstimatedArrivalTime' => '',
    'tasksCount' => ''
  ],
  'taskTtl' => '',
  'tombstoneTtl' => '',
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v2beta3/:parent/queues');
$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}}/v2beta3/:parent/queues' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta3/:parent/queues' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}'
import http.client

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

payload = "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}"

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

conn.request("POST", "/baseUrl/v2beta3/:parent/queues", payload, headers)

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

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

url = "{{baseUrl}}/v2beta3/:parent/queues"

payload = {
    "appEngineHttpQueue": { "appEngineRoutingOverride": {
            "host": "",
            "instance": "",
            "service": "",
            "version": ""
        } },
    "httpTarget": {
        "headerOverrides": [{ "header": {
                    "key": "",
                    "value": ""
                } }],
        "httpMethod": "",
        "uriOverride": {
            "host": "",
            "pathOverride": { "path": "" },
            "port": "",
            "queryOverride": { "queryParams": "" },
            "scheme": "",
            "uriOverrideEnforceMode": ""
        }
    },
    "name": "",
    "purgeTime": "",
    "rateLimits": {
        "maxBurstSize": 0,
        "maxConcurrentDispatches": 0,
        "maxDispatchesPerSecond": ""
    },
    "retryConfig": {
        "maxAttempts": 0,
        "maxBackoff": "",
        "maxDoublings": 0,
        "maxRetryDuration": "",
        "minBackoff": ""
    },
    "stackdriverLoggingConfig": { "samplingRatio": "" },
    "state": "",
    "stats": {
        "concurrentDispatchesCount": "",
        "effectiveExecutionRate": "",
        "executedLastMinuteCount": "",
        "oldestEstimatedArrivalTime": "",
        "tasksCount": ""
    },
    "taskTtl": "",
    "tombstoneTtl": "",
    "type": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta3/:parent/queues"

payload <- "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\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}}/v2beta3/:parent/queues")

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  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\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/v2beta3/:parent/queues') do |req|
  req.body = "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}"
end

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

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

    let payload = json!({
        "appEngineHttpQueue": json!({"appEngineRoutingOverride": json!({
                "host": "",
                "instance": "",
                "service": "",
                "version": ""
            })}),
        "httpTarget": json!({
            "headerOverrides": (json!({"header": json!({
                        "key": "",
                        "value": ""
                    })})),
            "httpMethod": "",
            "uriOverride": json!({
                "host": "",
                "pathOverride": json!({"path": ""}),
                "port": "",
                "queryOverride": json!({"queryParams": ""}),
                "scheme": "",
                "uriOverrideEnforceMode": ""
            })
        }),
        "name": "",
        "purgeTime": "",
        "rateLimits": json!({
            "maxBurstSize": 0,
            "maxConcurrentDispatches": 0,
            "maxDispatchesPerSecond": ""
        }),
        "retryConfig": json!({
            "maxAttempts": 0,
            "maxBackoff": "",
            "maxDoublings": 0,
            "maxRetryDuration": "",
            "minBackoff": ""
        }),
        "stackdriverLoggingConfig": json!({"samplingRatio": ""}),
        "state": "",
        "stats": json!({
            "concurrentDispatchesCount": "",
            "effectiveExecutionRate": "",
            "executedLastMinuteCount": "",
            "oldestEstimatedArrivalTime": "",
            "tasksCount": ""
        }),
        "taskTtl": "",
        "tombstoneTtl": "",
        "type": ""
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v2beta3/:parent/queues \
  --header 'content-type: application/json' \
  --data '{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}'
echo '{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}' |  \
  http POST {{baseUrl}}/v2beta3/:parent/queues \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "appEngineHttpQueue": {\n    "appEngineRoutingOverride": {\n      "host": "",\n      "instance": "",\n      "service": "",\n      "version": ""\n    }\n  },\n  "httpTarget": {\n    "headerOverrides": [\n      {\n        "header": {\n          "key": "",\n          "value": ""\n        }\n      }\n    ],\n    "httpMethod": "",\n    "uriOverride": {\n      "host": "",\n      "pathOverride": {\n        "path": ""\n      },\n      "port": "",\n      "queryOverride": {\n        "queryParams": ""\n      },\n      "scheme": "",\n      "uriOverrideEnforceMode": ""\n    }\n  },\n  "name": "",\n  "purgeTime": "",\n  "rateLimits": {\n    "maxBurstSize": 0,\n    "maxConcurrentDispatches": 0,\n    "maxDispatchesPerSecond": ""\n  },\n  "retryConfig": {\n    "maxAttempts": 0,\n    "maxBackoff": "",\n    "maxDoublings": 0,\n    "maxRetryDuration": "",\n    "minBackoff": ""\n  },\n  "stackdriverLoggingConfig": {\n    "samplingRatio": ""\n  },\n  "state": "",\n  "stats": {\n    "concurrentDispatchesCount": "",\n    "effectiveExecutionRate": "",\n    "executedLastMinuteCount": "",\n    "oldestEstimatedArrivalTime": "",\n    "tasksCount": ""\n  },\n  "taskTtl": "",\n  "tombstoneTtl": "",\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta3/:parent/queues
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "appEngineHttpQueue": ["appEngineRoutingOverride": [
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    ]],
  "httpTarget": [
    "headerOverrides": [["header": [
          "key": "",
          "value": ""
        ]]],
    "httpMethod": "",
    "uriOverride": [
      "host": "",
      "pathOverride": ["path": ""],
      "port": "",
      "queryOverride": ["queryParams": ""],
      "scheme": "",
      "uriOverrideEnforceMode": ""
    ]
  ],
  "name": "",
  "purgeTime": "",
  "rateLimits": [
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  ],
  "retryConfig": [
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  ],
  "stackdriverLoggingConfig": ["samplingRatio": ""],
  "state": "",
  "stats": [
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  ],
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
] as [String : Any]

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

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

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

dataTask.resume()
POST cloudtasks.projects.locations.queues.getIamPolicy
{{baseUrl}}/v2beta3/:resource:getIamPolicy
QUERY PARAMS

resource
BODY json

{
  "options": {
    "requestedPolicyVersion": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta3/:resource:getIamPolicy");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}");

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

(client/post "{{baseUrl}}/v2beta3/:resource:getIamPolicy" {:content-type :json
                                                                           :form-params {:options {:requestedPolicyVersion 0}}})
require "http/client"

url = "{{baseUrl}}/v2beta3/:resource:getIamPolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}"

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

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

func main() {

	url := "{{baseUrl}}/v2beta3/:resource:getIamPolicy"

	payload := strings.NewReader("{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v2beta3/:resource:getIamPolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 54

{
  "options": {
    "requestedPolicyVersion": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta3/:resource:getIamPolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta3/:resource:getIamPolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta3/:resource:getIamPolicy")
  .header("content-type", "application/json")
  .body("{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  options: {
    requestedPolicyVersion: 0
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta3/:resource:getIamPolicy');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:resource:getIamPolicy',
  headers: {'content-type': 'application/json'},
  data: {options: {requestedPolicyVersion: 0}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta3/:resource:getIamPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"options":{"requestedPolicyVersion":0}}'
};

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

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta3/:resource:getIamPolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

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

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:resource:getIamPolicy',
  headers: {'content-type': 'application/json'},
  body: {options: {requestedPolicyVersion: 0}},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta3/:resource:getIamPolicy');

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

req.type('json');
req.send({
  options: {
    requestedPolicyVersion: 0
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:resource:getIamPolicy',
  headers: {'content-type': 'application/json'},
  data: {options: {requestedPolicyVersion: 0}}
};

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

const url = '{{baseUrl}}/v2beta3/:resource:getIamPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"options":{"requestedPolicyVersion":0}}'
};

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

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

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v2beta3/:resource:getIamPolicy" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}" in

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

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v2beta3/:resource:getIamPolicy', [
  'body' => '{
  "options": {
    "requestedPolicyVersion": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta3/:resource:getIamPolicy');
$request->setMethod(HTTP_METH_POST);

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'options' => [
    'requestedPolicyVersion' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v2beta3/:resource:getIamPolicy');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

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

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

payload = "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}"

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

conn.request("POST", "/baseUrl/v2beta3/:resource:getIamPolicy", payload, headers)

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

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

url = "{{baseUrl}}/v2beta3/:resource:getIamPolicy"

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

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

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

url <- "{{baseUrl}}/v2beta3/:resource:getIamPolicy"

payload <- "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v2beta3/:resource:getIamPolicy")

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

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

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

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

response = conn.post('/baseUrl/v2beta3/:resource:getIamPolicy') do |req|
  req.body = "{\n  \"options\": {\n    \"requestedPolicyVersion\": 0\n  }\n}"
end

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

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

    let payload = json!({"options": json!({"requestedPolicyVersion": 0})});

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v2beta3/:resource:getIamPolicy \
  --header 'content-type: application/json' \
  --data '{
  "options": {
    "requestedPolicyVersion": 0
  }
}'
echo '{
  "options": {
    "requestedPolicyVersion": 0
  }
}' |  \
  http POST {{baseUrl}}/v2beta3/:resource:getIamPolicy \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "options": {\n    "requestedPolicyVersion": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v2beta3/:resource:getIamPolicy
import Foundation

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

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

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

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

dataTask.resume()
GET cloudtasks.projects.locations.queues.list
{{baseUrl}}/v2beta3/:parent/queues
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/v2beta3/:parent/queues")
require "http/client"

url = "{{baseUrl}}/v2beta3/:parent/queues"

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

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

func main() {

	url := "{{baseUrl}}/v2beta3/:parent/queues"

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v2beta3/:parent/queues'};

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

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

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

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

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

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

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

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

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}}/v2beta3/:parent/queues'};

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/v2beta3/:parent/queues")

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

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

url = "{{baseUrl}}/v2beta3/:parent/queues"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta3/:parent/queues"

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

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

url = URI("{{baseUrl}}/v2beta3/:parent/queues")

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

dataTask.resume()
PATCH cloudtasks.projects.locations.queues.patch
{{baseUrl}}/v2beta3/:name
QUERY PARAMS

name
BODY json

{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}");

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

(client/patch "{{baseUrl}}/v2beta3/:name" {:content-type :json
                                                           :form-params {:appEngineHttpQueue {:appEngineRoutingOverride {:host ""
                                                                                                                         :instance ""
                                                                                                                         :service ""
                                                                                                                         :version ""}}
                                                                         :httpTarget {:headerOverrides [{:header {:key ""
                                                                                                                  :value ""}}]
                                                                                      :httpMethod ""
                                                                                      :uriOverride {:host ""
                                                                                                    :pathOverride {:path ""}
                                                                                                    :port ""
                                                                                                    :queryOverride {:queryParams ""}
                                                                                                    :scheme ""
                                                                                                    :uriOverrideEnforceMode ""}}
                                                                         :name ""
                                                                         :purgeTime ""
                                                                         :rateLimits {:maxBurstSize 0
                                                                                      :maxConcurrentDispatches 0
                                                                                      :maxDispatchesPerSecond ""}
                                                                         :retryConfig {:maxAttempts 0
                                                                                       :maxBackoff ""
                                                                                       :maxDoublings 0
                                                                                       :maxRetryDuration ""
                                                                                       :minBackoff ""}
                                                                         :stackdriverLoggingConfig {:samplingRatio ""}
                                                                         :state ""
                                                                         :stats {:concurrentDispatchesCount ""
                                                                                 :effectiveExecutionRate ""
                                                                                 :executedLastMinuteCount ""
                                                                                 :oldestEstimatedArrivalTime ""
                                                                                 :tasksCount ""}
                                                                         :taskTtl ""
                                                                         :tombstoneTtl ""
                                                                         :type ""}})
require "http/client"

url = "{{baseUrl}}/v2beta3/:name"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}"

response = HTTP::Client.patch url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Patch,
    RequestUri = new Uri("{{baseUrl}}/v2beta3/:name"),
    Content = new StringContent("{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\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}}/v2beta3/:name");
var request = new RestRequest("", Method.Patch);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}")

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

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

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

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

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

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

{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/v2beta3/:name")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta3/:name"))
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\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  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta3/:name")
  .patch(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/v2beta3/:name")
  .header("content-type", "application/json")
  .body("{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  appEngineHttpQueue: {
    appEngineRoutingOverride: {
      host: '',
      instance: '',
      service: '',
      version: ''
    }
  },
  httpTarget: {
    headerOverrides: [
      {
        header: {
          key: '',
          value: ''
        }
      }
    ],
    httpMethod: '',
    uriOverride: {
      host: '',
      pathOverride: {
        path: ''
      },
      port: '',
      queryOverride: {
        queryParams: ''
      },
      scheme: '',
      uriOverrideEnforceMode: ''
    }
  },
  name: '',
  purgeTime: '',
  rateLimits: {
    maxBurstSize: 0,
    maxConcurrentDispatches: 0,
    maxDispatchesPerSecond: ''
  },
  retryConfig: {
    maxAttempts: 0,
    maxBackoff: '',
    maxDoublings: 0,
    maxRetryDuration: '',
    minBackoff: ''
  },
  stackdriverLoggingConfig: {
    samplingRatio: ''
  },
  state: '',
  stats: {
    concurrentDispatchesCount: '',
    effectiveExecutionRate: '',
    executedLastMinuteCount: '',
    oldestEstimatedArrivalTime: '',
    tasksCount: ''
  },
  taskTtl: '',
  tombstoneTtl: '',
  type: ''
});

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

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

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

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/v2beta3/:name',
  headers: {'content-type': 'application/json'},
  data: {
    appEngineHttpQueue: {appEngineRoutingOverride: {host: '', instance: '', service: '', version: ''}},
    httpTarget: {
      headerOverrides: [{header: {key: '', value: ''}}],
      httpMethod: '',
      uriOverride: {
        host: '',
        pathOverride: {path: ''},
        port: '',
        queryOverride: {queryParams: ''},
        scheme: '',
        uriOverrideEnforceMode: ''
      }
    },
    name: '',
    purgeTime: '',
    rateLimits: {maxBurstSize: 0, maxConcurrentDispatches: 0, maxDispatchesPerSecond: ''},
    retryConfig: {
      maxAttempts: 0,
      maxBackoff: '',
      maxDoublings: 0,
      maxRetryDuration: '',
      minBackoff: ''
    },
    stackdriverLoggingConfig: {samplingRatio: ''},
    state: '',
    stats: {
      concurrentDispatchesCount: '',
      effectiveExecutionRate: '',
      executedLastMinuteCount: '',
      oldestEstimatedArrivalTime: '',
      tasksCount: ''
    },
    taskTtl: '',
    tombstoneTtl: '',
    type: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta3/:name';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"appEngineHttpQueue":{"appEngineRoutingOverride":{"host":"","instance":"","service":"","version":""}},"httpTarget":{"headerOverrides":[{"header":{"key":"","value":""}}],"httpMethod":"","uriOverride":{"host":"","pathOverride":{"path":""},"port":"","queryOverride":{"queryParams":""},"scheme":"","uriOverrideEnforceMode":""}},"name":"","purgeTime":"","rateLimits":{"maxBurstSize":0,"maxConcurrentDispatches":0,"maxDispatchesPerSecond":""},"retryConfig":{"maxAttempts":0,"maxBackoff":"","maxDoublings":0,"maxRetryDuration":"","minBackoff":""},"stackdriverLoggingConfig":{"samplingRatio":""},"state":"","stats":{"concurrentDispatchesCount":"","effectiveExecutionRate":"","executedLastMinuteCount":"","oldestEstimatedArrivalTime":"","tasksCount":""},"taskTtl":"","tombstoneTtl":"","type":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta3/:name',
  method: 'PATCH',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "appEngineHttpQueue": {\n    "appEngineRoutingOverride": {\n      "host": "",\n      "instance": "",\n      "service": "",\n      "version": ""\n    }\n  },\n  "httpTarget": {\n    "headerOverrides": [\n      {\n        "header": {\n          "key": "",\n          "value": ""\n        }\n      }\n    ],\n    "httpMethod": "",\n    "uriOverride": {\n      "host": "",\n      "pathOverride": {\n        "path": ""\n      },\n      "port": "",\n      "queryOverride": {\n        "queryParams": ""\n      },\n      "scheme": "",\n      "uriOverrideEnforceMode": ""\n    }\n  },\n  "name": "",\n  "purgeTime": "",\n  "rateLimits": {\n    "maxBurstSize": 0,\n    "maxConcurrentDispatches": 0,\n    "maxDispatchesPerSecond": ""\n  },\n  "retryConfig": {\n    "maxAttempts": 0,\n    "maxBackoff": "",\n    "maxDoublings": 0,\n    "maxRetryDuration": "",\n    "minBackoff": ""\n  },\n  "stackdriverLoggingConfig": {\n    "samplingRatio": ""\n  },\n  "state": "",\n  "stats": {\n    "concurrentDispatchesCount": "",\n    "effectiveExecutionRate": "",\n    "executedLastMinuteCount": "",\n    "oldestEstimatedArrivalTime": "",\n    "tasksCount": ""\n  },\n  "taskTtl": "",\n  "tombstoneTtl": "",\n  "type": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta3/:name")
  .patch(body)
  .addHeader("content-type", "application/json")
  .build()

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

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

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

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

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

req.write(JSON.stringify({
  appEngineHttpQueue: {appEngineRoutingOverride: {host: '', instance: '', service: '', version: ''}},
  httpTarget: {
    headerOverrides: [{header: {key: '', value: ''}}],
    httpMethod: '',
    uriOverride: {
      host: '',
      pathOverride: {path: ''},
      port: '',
      queryOverride: {queryParams: ''},
      scheme: '',
      uriOverrideEnforceMode: ''
    }
  },
  name: '',
  purgeTime: '',
  rateLimits: {maxBurstSize: 0, maxConcurrentDispatches: 0, maxDispatchesPerSecond: ''},
  retryConfig: {
    maxAttempts: 0,
    maxBackoff: '',
    maxDoublings: 0,
    maxRetryDuration: '',
    minBackoff: ''
  },
  stackdriverLoggingConfig: {samplingRatio: ''},
  state: '',
  stats: {
    concurrentDispatchesCount: '',
    effectiveExecutionRate: '',
    executedLastMinuteCount: '',
    oldestEstimatedArrivalTime: '',
    tasksCount: ''
  },
  taskTtl: '',
  tombstoneTtl: '',
  type: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/v2beta3/:name',
  headers: {'content-type': 'application/json'},
  body: {
    appEngineHttpQueue: {appEngineRoutingOverride: {host: '', instance: '', service: '', version: ''}},
    httpTarget: {
      headerOverrides: [{header: {key: '', value: ''}}],
      httpMethod: '',
      uriOverride: {
        host: '',
        pathOverride: {path: ''},
        port: '',
        queryOverride: {queryParams: ''},
        scheme: '',
        uriOverrideEnforceMode: ''
      }
    },
    name: '',
    purgeTime: '',
    rateLimits: {maxBurstSize: 0, maxConcurrentDispatches: 0, maxDispatchesPerSecond: ''},
    retryConfig: {
      maxAttempts: 0,
      maxBackoff: '',
      maxDoublings: 0,
      maxRetryDuration: '',
      minBackoff: ''
    },
    stackdriverLoggingConfig: {samplingRatio: ''},
    state: '',
    stats: {
      concurrentDispatchesCount: '',
      effectiveExecutionRate: '',
      executedLastMinuteCount: '',
      oldestEstimatedArrivalTime: '',
      tasksCount: ''
    },
    taskTtl: '',
    tombstoneTtl: '',
    type: ''
  },
  json: true
};

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

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

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

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

req.type('json');
req.send({
  appEngineHttpQueue: {
    appEngineRoutingOverride: {
      host: '',
      instance: '',
      service: '',
      version: ''
    }
  },
  httpTarget: {
    headerOverrides: [
      {
        header: {
          key: '',
          value: ''
        }
      }
    ],
    httpMethod: '',
    uriOverride: {
      host: '',
      pathOverride: {
        path: ''
      },
      port: '',
      queryOverride: {
        queryParams: ''
      },
      scheme: '',
      uriOverrideEnforceMode: ''
    }
  },
  name: '',
  purgeTime: '',
  rateLimits: {
    maxBurstSize: 0,
    maxConcurrentDispatches: 0,
    maxDispatchesPerSecond: ''
  },
  retryConfig: {
    maxAttempts: 0,
    maxBackoff: '',
    maxDoublings: 0,
    maxRetryDuration: '',
    minBackoff: ''
  },
  stackdriverLoggingConfig: {
    samplingRatio: ''
  },
  state: '',
  stats: {
    concurrentDispatchesCount: '',
    effectiveExecutionRate: '',
    executedLastMinuteCount: '',
    oldestEstimatedArrivalTime: '',
    tasksCount: ''
  },
  taskTtl: '',
  tombstoneTtl: '',
  type: ''
});

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

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/v2beta3/:name',
  headers: {'content-type': 'application/json'},
  data: {
    appEngineHttpQueue: {appEngineRoutingOverride: {host: '', instance: '', service: '', version: ''}},
    httpTarget: {
      headerOverrides: [{header: {key: '', value: ''}}],
      httpMethod: '',
      uriOverride: {
        host: '',
        pathOverride: {path: ''},
        port: '',
        queryOverride: {queryParams: ''},
        scheme: '',
        uriOverrideEnforceMode: ''
      }
    },
    name: '',
    purgeTime: '',
    rateLimits: {maxBurstSize: 0, maxConcurrentDispatches: 0, maxDispatchesPerSecond: ''},
    retryConfig: {
      maxAttempts: 0,
      maxBackoff: '',
      maxDoublings: 0,
      maxRetryDuration: '',
      minBackoff: ''
    },
    stackdriverLoggingConfig: {samplingRatio: ''},
    state: '',
    stats: {
      concurrentDispatchesCount: '',
      effectiveExecutionRate: '',
      executedLastMinuteCount: '',
      oldestEstimatedArrivalTime: '',
      tasksCount: ''
    },
    taskTtl: '',
    tombstoneTtl: '',
    type: ''
  }
};

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

const url = '{{baseUrl}}/v2beta3/:name';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"appEngineHttpQueue":{"appEngineRoutingOverride":{"host":"","instance":"","service":"","version":""}},"httpTarget":{"headerOverrides":[{"header":{"key":"","value":""}}],"httpMethod":"","uriOverride":{"host":"","pathOverride":{"path":""},"port":"","queryOverride":{"queryParams":""},"scheme":"","uriOverrideEnforceMode":""}},"name":"","purgeTime":"","rateLimits":{"maxBurstSize":0,"maxConcurrentDispatches":0,"maxDispatchesPerSecond":""},"retryConfig":{"maxAttempts":0,"maxBackoff":"","maxDoublings":0,"maxRetryDuration":"","minBackoff":""},"stackdriverLoggingConfig":{"samplingRatio":""},"state":"","stats":{"concurrentDispatchesCount":"","effectiveExecutionRate":"","executedLastMinuteCount":"","oldestEstimatedArrivalTime":"","tasksCount":""},"taskTtl":"","tombstoneTtl":"","type":""}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"appEngineHttpQueue": @{ @"appEngineRoutingOverride": @{ @"host": @"", @"instance": @"", @"service": @"", @"version": @"" } },
                              @"httpTarget": @{ @"headerOverrides": @[ @{ @"header": @{ @"key": @"", @"value": @"" } } ], @"httpMethod": @"", @"uriOverride": @{ @"host": @"", @"pathOverride": @{ @"path": @"" }, @"port": @"", @"queryOverride": @{ @"queryParams": @"" }, @"scheme": @"", @"uriOverrideEnforceMode": @"" } },
                              @"name": @"",
                              @"purgeTime": @"",
                              @"rateLimits": @{ @"maxBurstSize": @0, @"maxConcurrentDispatches": @0, @"maxDispatchesPerSecond": @"" },
                              @"retryConfig": @{ @"maxAttempts": @0, @"maxBackoff": @"", @"maxDoublings": @0, @"maxRetryDuration": @"", @"minBackoff": @"" },
                              @"stackdriverLoggingConfig": @{ @"samplingRatio": @"" },
                              @"state": @"",
                              @"stats": @{ @"concurrentDispatchesCount": @"", @"effectiveExecutionRate": @"", @"executedLastMinuteCount": @"", @"oldestEstimatedArrivalTime": @"", @"tasksCount": @"" },
                              @"taskTtl": @"",
                              @"tombstoneTtl": @"",
                              @"type": @"" };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v2beta3/:name" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta3/:name",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PATCH",
  CURLOPT_POSTFIELDS => json_encode([
    'appEngineHttpQueue' => [
        'appEngineRoutingOverride' => [
                'host' => '',
                'instance' => '',
                'service' => '',
                'version' => ''
        ]
    ],
    'httpTarget' => [
        'headerOverrides' => [
                [
                                'header' => [
                                                                'key' => '',
                                                                'value' => ''
                                ]
                ]
        ],
        'httpMethod' => '',
        'uriOverride' => [
                'host' => '',
                'pathOverride' => [
                                'path' => ''
                ],
                'port' => '',
                'queryOverride' => [
                                'queryParams' => ''
                ],
                'scheme' => '',
                'uriOverrideEnforceMode' => ''
        ]
    ],
    'name' => '',
    'purgeTime' => '',
    'rateLimits' => [
        'maxBurstSize' => 0,
        'maxConcurrentDispatches' => 0,
        'maxDispatchesPerSecond' => ''
    ],
    'retryConfig' => [
        'maxAttempts' => 0,
        'maxBackoff' => '',
        'maxDoublings' => 0,
        'maxRetryDuration' => '',
        'minBackoff' => ''
    ],
    'stackdriverLoggingConfig' => [
        'samplingRatio' => ''
    ],
    'state' => '',
    'stats' => [
        'concurrentDispatchesCount' => '',
        'effectiveExecutionRate' => '',
        'executedLastMinuteCount' => '',
        'oldestEstimatedArrivalTime' => '',
        'tasksCount' => ''
    ],
    'taskTtl' => '',
    'tombstoneTtl' => '',
    'type' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PATCH', '{{baseUrl}}/v2beta3/:name', [
  'body' => '{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'appEngineHttpQueue' => [
    'appEngineRoutingOverride' => [
        'host' => '',
        'instance' => '',
        'service' => '',
        'version' => ''
    ]
  ],
  'httpTarget' => [
    'headerOverrides' => [
        [
                'header' => [
                                'key' => '',
                                'value' => ''
                ]
        ]
    ],
    'httpMethod' => '',
    'uriOverride' => [
        'host' => '',
        'pathOverride' => [
                'path' => ''
        ],
        'port' => '',
        'queryOverride' => [
                'queryParams' => ''
        ],
        'scheme' => '',
        'uriOverrideEnforceMode' => ''
    ]
  ],
  'name' => '',
  'purgeTime' => '',
  'rateLimits' => [
    'maxBurstSize' => 0,
    'maxConcurrentDispatches' => 0,
    'maxDispatchesPerSecond' => ''
  ],
  'retryConfig' => [
    'maxAttempts' => 0,
    'maxBackoff' => '',
    'maxDoublings' => 0,
    'maxRetryDuration' => '',
    'minBackoff' => ''
  ],
  'stackdriverLoggingConfig' => [
    'samplingRatio' => ''
  ],
  'state' => '',
  'stats' => [
    'concurrentDispatchesCount' => '',
    'effectiveExecutionRate' => '',
    'executedLastMinuteCount' => '',
    'oldestEstimatedArrivalTime' => '',
    'tasksCount' => ''
  ],
  'taskTtl' => '',
  'tombstoneTtl' => '',
  'type' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'appEngineHttpQueue' => [
    'appEngineRoutingOverride' => [
        'host' => '',
        'instance' => '',
        'service' => '',
        'version' => ''
    ]
  ],
  'httpTarget' => [
    'headerOverrides' => [
        [
                'header' => [
                                'key' => '',
                                'value' => ''
                ]
        ]
    ],
    'httpMethod' => '',
    'uriOverride' => [
        'host' => '',
        'pathOverride' => [
                'path' => ''
        ],
        'port' => '',
        'queryOverride' => [
                'queryParams' => ''
        ],
        'scheme' => '',
        'uriOverrideEnforceMode' => ''
    ]
  ],
  'name' => '',
  'purgeTime' => '',
  'rateLimits' => [
    'maxBurstSize' => 0,
    'maxConcurrentDispatches' => 0,
    'maxDispatchesPerSecond' => ''
  ],
  'retryConfig' => [
    'maxAttempts' => 0,
    'maxBackoff' => '',
    'maxDoublings' => 0,
    'maxRetryDuration' => '',
    'minBackoff' => ''
  ],
  'stackdriverLoggingConfig' => [
    'samplingRatio' => ''
  ],
  'state' => '',
  'stats' => [
    'concurrentDispatchesCount' => '',
    'effectiveExecutionRate' => '',
    'executedLastMinuteCount' => '',
    'oldestEstimatedArrivalTime' => '',
    'tasksCount' => ''
  ],
  'taskTtl' => '',
  'tombstoneTtl' => '',
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v2beta3/:name');
$request->setRequestMethod('PATCH');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta3/:name' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta3/:name' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}'
import http.client

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

payload = "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}"

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

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

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

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

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

payload = {
    "appEngineHttpQueue": { "appEngineRoutingOverride": {
            "host": "",
            "instance": "",
            "service": "",
            "version": ""
        } },
    "httpTarget": {
        "headerOverrides": [{ "header": {
                    "key": "",
                    "value": ""
                } }],
        "httpMethod": "",
        "uriOverride": {
            "host": "",
            "pathOverride": { "path": "" },
            "port": "",
            "queryOverride": { "queryParams": "" },
            "scheme": "",
            "uriOverrideEnforceMode": ""
        }
    },
    "name": "",
    "purgeTime": "",
    "rateLimits": {
        "maxBurstSize": 0,
        "maxConcurrentDispatches": 0,
        "maxDispatchesPerSecond": ""
    },
    "retryConfig": {
        "maxAttempts": 0,
        "maxBackoff": "",
        "maxDoublings": 0,
        "maxRetryDuration": "",
        "minBackoff": ""
    },
    "stackdriverLoggingConfig": { "samplingRatio": "" },
    "state": "",
    "stats": {
        "concurrentDispatchesCount": "",
        "effectiveExecutionRate": "",
        "executedLastMinuteCount": "",
        "oldestEstimatedArrivalTime": "",
        "tasksCount": ""
    },
    "taskTtl": "",
    "tombstoneTtl": "",
    "type": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}"

encode <- "json"

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

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

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

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

request = Net::HTTP::Patch.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}"

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

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

response = conn.patch('/baseUrl/v2beta3/:name') do |req|
  req.body = "{\n  \"appEngineHttpQueue\": {\n    \"appEngineRoutingOverride\": {\n      \"host\": \"\",\n      \"instance\": \"\",\n      \"service\": \"\",\n      \"version\": \"\"\n    }\n  },\n  \"httpTarget\": {\n    \"headerOverrides\": [\n      {\n        \"header\": {\n          \"key\": \"\",\n          \"value\": \"\"\n        }\n      }\n    ],\n    \"httpMethod\": \"\",\n    \"uriOverride\": {\n      \"host\": \"\",\n      \"pathOverride\": {\n        \"path\": \"\"\n      },\n      \"port\": \"\",\n      \"queryOverride\": {\n        \"queryParams\": \"\"\n      },\n      \"scheme\": \"\",\n      \"uriOverrideEnforceMode\": \"\"\n    }\n  },\n  \"name\": \"\",\n  \"purgeTime\": \"\",\n  \"rateLimits\": {\n    \"maxBurstSize\": 0,\n    \"maxConcurrentDispatches\": 0,\n    \"maxDispatchesPerSecond\": \"\"\n  },\n  \"retryConfig\": {\n    \"maxAttempts\": 0,\n    \"maxBackoff\": \"\",\n    \"maxDoublings\": 0,\n    \"maxRetryDuration\": \"\",\n    \"minBackoff\": \"\"\n  },\n  \"stackdriverLoggingConfig\": {\n    \"samplingRatio\": \"\"\n  },\n  \"state\": \"\",\n  \"stats\": {\n    \"concurrentDispatchesCount\": \"\",\n    \"effectiveExecutionRate\": \"\",\n    \"executedLastMinuteCount\": \"\",\n    \"oldestEstimatedArrivalTime\": \"\",\n    \"tasksCount\": \"\"\n  },\n  \"taskTtl\": \"\",\n  \"tombstoneTtl\": \"\",\n  \"type\": \"\"\n}"
end

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

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

    let payload = json!({
        "appEngineHttpQueue": json!({"appEngineRoutingOverride": json!({
                "host": "",
                "instance": "",
                "service": "",
                "version": ""
            })}),
        "httpTarget": json!({
            "headerOverrides": (json!({"header": json!({
                        "key": "",
                        "value": ""
                    })})),
            "httpMethod": "",
            "uriOverride": json!({
                "host": "",
                "pathOverride": json!({"path": ""}),
                "port": "",
                "queryOverride": json!({"queryParams": ""}),
                "scheme": "",
                "uriOverrideEnforceMode": ""
            })
        }),
        "name": "",
        "purgeTime": "",
        "rateLimits": json!({
            "maxBurstSize": 0,
            "maxConcurrentDispatches": 0,
            "maxDispatchesPerSecond": ""
        }),
        "retryConfig": json!({
            "maxAttempts": 0,
            "maxBackoff": "",
            "maxDoublings": 0,
            "maxRetryDuration": "",
            "minBackoff": ""
        }),
        "stackdriverLoggingConfig": json!({"samplingRatio": ""}),
        "state": "",
        "stats": json!({
            "concurrentDispatchesCount": "",
            "effectiveExecutionRate": "",
            "executedLastMinuteCount": "",
            "oldestEstimatedArrivalTime": "",
            "tasksCount": ""
        }),
        "taskTtl": "",
        "tombstoneTtl": "",
        "type": ""
    });

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

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

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

    dbg!(results);
}
curl --request PATCH \
  --url {{baseUrl}}/v2beta3/:name \
  --header 'content-type: application/json' \
  --data '{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}'
echo '{
  "appEngineHttpQueue": {
    "appEngineRoutingOverride": {
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    }
  },
  "httpTarget": {
    "headerOverrides": [
      {
        "header": {
          "key": "",
          "value": ""
        }
      }
    ],
    "httpMethod": "",
    "uriOverride": {
      "host": "",
      "pathOverride": {
        "path": ""
      },
      "port": "",
      "queryOverride": {
        "queryParams": ""
      },
      "scheme": "",
      "uriOverrideEnforceMode": ""
    }
  },
  "name": "",
  "purgeTime": "",
  "rateLimits": {
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  },
  "retryConfig": {
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  },
  "stackdriverLoggingConfig": {
    "samplingRatio": ""
  },
  "state": "",
  "stats": {
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  },
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
}' |  \
  http PATCH {{baseUrl}}/v2beta3/:name \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'content-type: application/json' \
  --body-data '{\n  "appEngineHttpQueue": {\n    "appEngineRoutingOverride": {\n      "host": "",\n      "instance": "",\n      "service": "",\n      "version": ""\n    }\n  },\n  "httpTarget": {\n    "headerOverrides": [\n      {\n        "header": {\n          "key": "",\n          "value": ""\n        }\n      }\n    ],\n    "httpMethod": "",\n    "uriOverride": {\n      "host": "",\n      "pathOverride": {\n        "path": ""\n      },\n      "port": "",\n      "queryOverride": {\n        "queryParams": ""\n      },\n      "scheme": "",\n      "uriOverrideEnforceMode": ""\n    }\n  },\n  "name": "",\n  "purgeTime": "",\n  "rateLimits": {\n    "maxBurstSize": 0,\n    "maxConcurrentDispatches": 0,\n    "maxDispatchesPerSecond": ""\n  },\n  "retryConfig": {\n    "maxAttempts": 0,\n    "maxBackoff": "",\n    "maxDoublings": 0,\n    "maxRetryDuration": "",\n    "minBackoff": ""\n  },\n  "stackdriverLoggingConfig": {\n    "samplingRatio": ""\n  },\n  "state": "",\n  "stats": {\n    "concurrentDispatchesCount": "",\n    "effectiveExecutionRate": "",\n    "executedLastMinuteCount": "",\n    "oldestEstimatedArrivalTime": "",\n    "tasksCount": ""\n  },\n  "taskTtl": "",\n  "tombstoneTtl": "",\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta3/:name
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "appEngineHttpQueue": ["appEngineRoutingOverride": [
      "host": "",
      "instance": "",
      "service": "",
      "version": ""
    ]],
  "httpTarget": [
    "headerOverrides": [["header": [
          "key": "",
          "value": ""
        ]]],
    "httpMethod": "",
    "uriOverride": [
      "host": "",
      "pathOverride": ["path": ""],
      "port": "",
      "queryOverride": ["queryParams": ""],
      "scheme": "",
      "uriOverrideEnforceMode": ""
    ]
  ],
  "name": "",
  "purgeTime": "",
  "rateLimits": [
    "maxBurstSize": 0,
    "maxConcurrentDispatches": 0,
    "maxDispatchesPerSecond": ""
  ],
  "retryConfig": [
    "maxAttempts": 0,
    "maxBackoff": "",
    "maxDoublings": 0,
    "maxRetryDuration": "",
    "minBackoff": ""
  ],
  "stackdriverLoggingConfig": ["samplingRatio": ""],
  "state": "",
  "stats": [
    "concurrentDispatchesCount": "",
    "effectiveExecutionRate": "",
    "executedLastMinuteCount": "",
    "oldestEstimatedArrivalTime": "",
    "tasksCount": ""
  ],
  "taskTtl": "",
  "tombstoneTtl": "",
  "type": ""
] as [String : Any]

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

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

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

dataTask.resume()
POST cloudtasks.projects.locations.queues.pause
{{baseUrl}}/v2beta3/:name:pause
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}}/v2beta3/:name:pause");

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}}/v2beta3/:name:pause" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v2beta3/:name:pause"
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}}/v2beta3/:name:pause"),
    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}}/v2beta3/:name:pause");
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}}/v2beta3/:name:pause"

	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/v2beta3/:name:pause HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta3/:name:pause"))
    .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}}/v2beta3/:name:pause")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta3/:name:pause")
  .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}}/v2beta3/:name:pause');
xhr.setRequestHeader('content-type', 'application/json');

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

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

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

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}}/v2beta3/:name:pause',
  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}}/v2beta3/:name:pause';
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}}/v2beta3/:name:pause"]
                                                       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}}/v2beta3/:name:pause" 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}}/v2beta3/:name:pause",
  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}}/v2beta3/:name:pause', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta3/:name:pause');
$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}}/v2beta3/:name:pause');
$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}}/v2beta3/:name:pause' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta3/:name:pause' -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/v2beta3/:name:pause", payload, headers)

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

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

url = "{{baseUrl}}/v2beta3/:name:pause"

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

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

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

url <- "{{baseUrl}}/v2beta3/:name:pause"

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}}/v2beta3/:name:pause")

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/v2beta3/:name:pause') 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}}/v2beta3/:name:pause";

    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}}/v2beta3/:name:pause \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v2beta3/:name:pause \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v2beta3/:name:pause
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}}/v2beta3/:name:pause")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
POST cloudtasks.projects.locations.queues.purge
{{baseUrl}}/v2beta3/:name:purge
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}}/v2beta3/:name:purge");

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}}/v2beta3/:name:purge" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v2beta3/:name:purge"
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}}/v2beta3/:name:purge"),
    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}}/v2beta3/:name:purge");
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}}/v2beta3/:name:purge"

	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/v2beta3/:name:purge HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta3/:name:purge"))
    .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}}/v2beta3/:name:purge")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta3/:name:purge")
  .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}}/v2beta3/:name:purge');
xhr.setRequestHeader('content-type', 'application/json');

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

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

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

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}}/v2beta3/:name:purge',
  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}}/v2beta3/:name:purge';
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}}/v2beta3/:name:purge"]
                                                       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}}/v2beta3/:name:purge" 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}}/v2beta3/:name:purge",
  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}}/v2beta3/:name:purge', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta3/:name:purge');
$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}}/v2beta3/:name:purge');
$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}}/v2beta3/:name:purge' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta3/:name:purge' -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/v2beta3/:name:purge", payload, headers)

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

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

url = "{{baseUrl}}/v2beta3/:name:purge"

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

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

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

url <- "{{baseUrl}}/v2beta3/:name:purge"

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}}/v2beta3/:name:purge")

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/v2beta3/:name:purge') 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}}/v2beta3/:name:purge";

    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}}/v2beta3/:name:purge \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v2beta3/:name:purge \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v2beta3/:name:purge
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}}/v2beta3/:name:purge")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
POST cloudtasks.projects.locations.queues.resume
{{baseUrl}}/v2beta3/:name:resume
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}}/v2beta3/:name:resume");

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}}/v2beta3/:name:resume" {:content-type :json})
require "http/client"

url = "{{baseUrl}}/v2beta3/:name:resume"
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}}/v2beta3/:name:resume"),
    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}}/v2beta3/:name:resume");
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}}/v2beta3/:name:resume"

	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/v2beta3/:name:resume HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 2

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

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta3/:name:resume"))
    .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}}/v2beta3/:name:resume")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta3/:name:resume")
  .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}}/v2beta3/:name:resume');
xhr.setRequestHeader('content-type', 'application/json');

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

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

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

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}}/v2beta3/:name:resume',
  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}}/v2beta3/:name:resume';
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}}/v2beta3/:name:resume"]
                                                       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}}/v2beta3/:name:resume" 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}}/v2beta3/:name:resume",
  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}}/v2beta3/:name:resume', [
  'body' => '{}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta3/:name:resume');
$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}}/v2beta3/:name:resume');
$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}}/v2beta3/:name:resume' -Method POST -Headers $headers -ContentType 'application/json' -Body '{}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta3/:name:resume' -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/v2beta3/:name:resume", payload, headers)

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

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

url = "{{baseUrl}}/v2beta3/:name:resume"

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

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

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

url <- "{{baseUrl}}/v2beta3/:name:resume"

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}}/v2beta3/:name:resume")

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/v2beta3/:name:resume') 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}}/v2beta3/:name:resume";

    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}}/v2beta3/:name:resume \
  --header 'content-type: application/json' \
  --data '{}'
echo '{}' |  \
  http POST {{baseUrl}}/v2beta3/:name:resume \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{}' \
  --output-document \
  - {{baseUrl}}/v2beta3/:name:resume
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}}/v2beta3/:name:resume")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
POST cloudtasks.projects.locations.queues.setIamPolicy
{{baseUrl}}/v2beta3/:resource:setIamPolicy
QUERY PARAMS

resource
BODY json

{
  "policy": {
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta3/:resource:setIamPolicy");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}");

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

(client/post "{{baseUrl}}/v2beta3/:resource:setIamPolicy" {:content-type :json
                                                                           :form-params {:policy {:bindings [{:condition {:description ""
                                                                                                                          :expression ""
                                                                                                                          :location ""
                                                                                                                          :title ""}
                                                                                                              :members []
                                                                                                              :role ""}]
                                                                                                  :etag ""
                                                                                                  :version 0}}})
require "http/client"

url = "{{baseUrl}}/v2beta3/:resource:setIamPolicy"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}"

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}}/v2beta3/:resource:setIamPolicy"),
    Content = new StringContent("{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}")
    {
        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}}/v2beta3/:resource:setIamPolicy");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta3/:resource:setIamPolicy"

	payload := strings.NewReader("{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}")

	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/v2beta3/:resource:setIamPolicy HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 276

{
  "policy": {
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta3/:resource:setIamPolicy")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta3/:resource:setIamPolicy"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta3/:resource:setIamPolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta3/:resource:setIamPolicy")
  .header("content-type", "application/json")
  .body("{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}")
  .asString();
const data = JSON.stringify({
  policy: {
    bindings: [
      {
        condition: {
          description: '',
          expression: '',
          location: '',
          title: ''
        },
        members: [],
        role: ''
      }
    ],
    etag: '',
    version: 0
  }
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta3/:resource:setIamPolicy');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:resource:setIamPolicy',
  headers: {'content-type': 'application/json'},
  data: {
    policy: {
      bindings: [
        {
          condition: {description: '', expression: '', location: '', title: ''},
          members: [],
          role: ''
        }
      ],
      etag: '',
      version: 0
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta3/:resource:setIamPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"policy":{"bindings":[{"condition":{"description":"","expression":"","location":"","title":""},"members":[],"role":""}],"etag":"","version":0}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v2beta3/:resource:setIamPolicy',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "policy": {\n    "bindings": [\n      {\n        "condition": {\n          "description": "",\n          "expression": "",\n          "location": "",\n          "title": ""\n        },\n        "members": [],\n        "role": ""\n      }\n    ],\n    "etag": "",\n    "version": 0\n  }\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta3/:resource:setIamPolicy")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

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

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

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

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

req.write(JSON.stringify({
  policy: {
    bindings: [
      {
        condition: {description: '', expression: '', location: '', title: ''},
        members: [],
        role: ''
      }
    ],
    etag: '',
    version: 0
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:resource:setIamPolicy',
  headers: {'content-type': 'application/json'},
  body: {
    policy: {
      bindings: [
        {
          condition: {description: '', expression: '', location: '', title: ''},
          members: [],
          role: ''
        }
      ],
      etag: '',
      version: 0
    }
  },
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta3/:resource:setIamPolicy');

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

req.type('json');
req.send({
  policy: {
    bindings: [
      {
        condition: {
          description: '',
          expression: '',
          location: '',
          title: ''
        },
        members: [],
        role: ''
      }
    ],
    etag: '',
    version: 0
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:resource:setIamPolicy',
  headers: {'content-type': 'application/json'},
  data: {
    policy: {
      bindings: [
        {
          condition: {description: '', expression: '', location: '', title: ''},
          members: [],
          role: ''
        }
      ],
      etag: '',
      version: 0
    }
  }
};

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

const url = '{{baseUrl}}/v2beta3/:resource:setIamPolicy';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"policy":{"bindings":[{"condition":{"description":"","expression":"","location":"","title":""},"members":[],"role":""}],"etag":"","version":0}}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"policy": @{ @"bindings": @[ @{ @"condition": @{ @"description": @"", @"expression": @"", @"location": @"", @"title": @"" }, @"members": @[  ], @"role": @"" } ], @"etag": @"", @"version": @0 } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v2beta3/:resource:setIamPolicy" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta3/:resource:setIamPolicy",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'policy' => [
        'bindings' => [
                [
                                'condition' => [
                                                                'description' => '',
                                                                'expression' => '',
                                                                'location' => '',
                                                                'title' => ''
                                ],
                                'members' => [
                                                                
                                ],
                                'role' => ''
                ]
        ],
        'etag' => '',
        'version' => 0
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v2beta3/:resource:setIamPolicy', [
  'body' => '{
  "policy": {
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta3/:resource:setIamPolicy');
$request->setMethod(HTTP_METH_POST);

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'policy' => [
    'bindings' => [
        [
                'condition' => [
                                'description' => '',
                                'expression' => '',
                                'location' => '',
                                'title' => ''
                ],
                'members' => [
                                
                ],
                'role' => ''
        ]
    ],
    'etag' => '',
    'version' => 0
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'policy' => [
    'bindings' => [
        [
                'condition' => [
                                'description' => '',
                                'expression' => '',
                                'location' => '',
                                'title' => ''
                ],
                'members' => [
                                
                ],
                'role' => ''
        ]
    ],
    'etag' => '',
    'version' => 0
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v2beta3/:resource:setIamPolicy');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v2beta3/:resource:setIamPolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "policy": {
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta3/:resource:setIamPolicy' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "policy": {
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  }
}'
import http.client

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

payload = "{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}"

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

conn.request("POST", "/baseUrl/v2beta3/:resource:setIamPolicy", payload, headers)

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

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

url = "{{baseUrl}}/v2beta3/:resource:setIamPolicy"

payload = { "policy": {
        "bindings": [
            {
                "condition": {
                    "description": "",
                    "expression": "",
                    "location": "",
                    "title": ""
                },
                "members": [],
                "role": ""
            }
        ],
        "etag": "",
        "version": 0
    } }
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta3/:resource:setIamPolicy"

payload <- "{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}"

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}}/v2beta3/:resource:setIamPolicy")

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}"

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/v2beta3/:resource:setIamPolicy') do |req|
  req.body = "{\n  \"policy\": {\n    \"bindings\": [\n      {\n        \"condition\": {\n          \"description\": \"\",\n          \"expression\": \"\",\n          \"location\": \"\",\n          \"title\": \"\"\n        },\n        \"members\": [],\n        \"role\": \"\"\n      }\n    ],\n    \"etag\": \"\",\n    \"version\": 0\n  }\n}"
end

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

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

    let payload = json!({"policy": json!({
            "bindings": (
                json!({
                    "condition": json!({
                        "description": "",
                        "expression": "",
                        "location": "",
                        "title": ""
                    }),
                    "members": (),
                    "role": ""
                })
            ),
            "etag": "",
            "version": 0
        })});

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v2beta3/:resource:setIamPolicy \
  --header 'content-type: application/json' \
  --data '{
  "policy": {
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  }
}'
echo '{
  "policy": {
    "bindings": [
      {
        "condition": {
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        },
        "members": [],
        "role": ""
      }
    ],
    "etag": "",
    "version": 0
  }
}' |  \
  http POST {{baseUrl}}/v2beta3/:resource:setIamPolicy \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "policy": {\n    "bindings": [\n      {\n        "condition": {\n          "description": "",\n          "expression": "",\n          "location": "",\n          "title": ""\n        },\n        "members": [],\n        "role": ""\n      }\n    ],\n    "etag": "",\n    "version": 0\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v2beta3/:resource:setIamPolicy
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["policy": [
    "bindings": [
      [
        "condition": [
          "description": "",
          "expression": "",
          "location": "",
          "title": ""
        ],
        "members": [],
        "role": ""
      ]
    ],
    "etag": "",
    "version": 0
  ]] as [String : Any]

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

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

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

dataTask.resume()
POST cloudtasks.projects.locations.queues.tasks.buffer
{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer
QUERY PARAMS

queue
taskId
BODY json

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

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer");

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

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

(client/post "{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer" {:content-type :json
                                                                                :form-params {:body {:contentType ""
                                                                                                     :data ""
                                                                                                     :extensions [{}]}}})
require "http/client"

url = "{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"body\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"

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

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

func main() {

	url := "{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer"

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

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

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

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

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

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

}
POST /baseUrl/v2beta3/:queue/tasks/:taskId:buffer HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 93

{
  "body": {
    "contentType": "",
    "data": "",
    "extensions": [
      {}
    ]
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"body\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

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

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

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

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

xhr.open('POST', '{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer',
  headers: {'content-type': 'application/json'},
  data: {body: {contentType: '', data: '', extensions: [{}]}}
};

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

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

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"body\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer")
  .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/v2beta3/:queue/tasks/:taskId:buffer',
  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({body: {contentType: '', data: '', extensions: [{}]}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer',
  headers: {'content-type': 'application/json'},
  body: {body: {contentType: '', data: '', extensions: [{}]}},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer');

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer',
  headers: {'content-type': 'application/json'},
  data: {body: {contentType: '', data: '', extensions: [{}]}}
};

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

const url = '{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"body":{"contentType":"","data":"","extensions":[{}]}}'
};

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

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

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer"]
                                                       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}}/v2beta3/:queue/tasks/:taskId:buffer" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"body\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer",
  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([
    'body' => [
        'contentType' => '',
        'data' => '',
        'extensions' => [
                [
                                
                ]
        ]
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

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

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer');
$request->setMethod(HTTP_METH_POST);

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

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

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

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

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

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

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

conn.request("POST", "/baseUrl/v2beta3/:queue/tasks/:taskId:buffer", payload, headers)

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

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

url = "{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer"

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

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

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

url <- "{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer"

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

encode <- "json"

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

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

url = URI("{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer")

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

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

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

response = conn.post('/baseUrl/v2beta3/:queue/tasks/:taskId:buffer') do |req|
  req.body = "{\n  \"body\": {\n    \"contentType\": \"\",\n    \"data\": \"\",\n    \"extensions\": [\n      {}\n    ]\n  }\n}"
end

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

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer";

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

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

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

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta3/:queue/tasks/:taskId:buffer")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "POST"
request.allHTTPHeaderFields = headers
request.httpBody = postData as Data

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

dataTask.resume()
POST cloudtasks.projects.locations.queues.tasks.create
{{baseUrl}}/v2beta3/:parent/tasks
QUERY PARAMS

parent
BODY json

{
  "responseView": "",
  "task": {
    "appEngineHttpRequest": {
      "appEngineRouting": {
        "host": "",
        "instance": "",
        "service": "",
        "version": ""
      },
      "body": "",
      "headers": {},
      "httpMethod": "",
      "relativeUri": ""
    },
    "createTime": "",
    "dispatchCount": 0,
    "dispatchDeadline": "",
    "firstAttempt": {
      "dispatchTime": "",
      "responseStatus": {
        "code": 0,
        "details": [
          {}
        ],
        "message": ""
      },
      "responseTime": "",
      "scheduleTime": ""
    },
    "httpRequest": {
      "body": "",
      "headers": {},
      "httpMethod": "",
      "oauthToken": {
        "scope": "",
        "serviceAccountEmail": ""
      },
      "oidcToken": {
        "audience": "",
        "serviceAccountEmail": ""
      },
      "url": ""
    },
    "lastAttempt": {},
    "name": "",
    "pullMessage": {
      "payload": "",
      "tag": ""
    },
    "responseCount": 0,
    "scheduleTime": "",
    "view": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}");

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

(client/post "{{baseUrl}}/v2beta3/:parent/tasks" {:content-type :json
                                                                  :form-params {:responseView ""
                                                                                :task {:appEngineHttpRequest {:appEngineRouting {:host ""
                                                                                                                                 :instance ""
                                                                                                                                 :service ""
                                                                                                                                 :version ""}
                                                                                                              :body ""
                                                                                                              :headers {}
                                                                                                              :httpMethod ""
                                                                                                              :relativeUri ""}
                                                                                       :createTime ""
                                                                                       :dispatchCount 0
                                                                                       :dispatchDeadline ""
                                                                                       :firstAttempt {:dispatchTime ""
                                                                                                      :responseStatus {:code 0
                                                                                                                       :details [{}]
                                                                                                                       :message ""}
                                                                                                      :responseTime ""
                                                                                                      :scheduleTime ""}
                                                                                       :httpRequest {:body ""
                                                                                                     :headers {}
                                                                                                     :httpMethod ""
                                                                                                     :oauthToken {:scope ""
                                                                                                                  :serviceAccountEmail ""}
                                                                                                     :oidcToken {:audience ""
                                                                                                                 :serviceAccountEmail ""}
                                                                                                     :url ""}
                                                                                       :lastAttempt {}
                                                                                       :name ""
                                                                                       :pullMessage {:payload ""
                                                                                                     :tag ""}
                                                                                       :responseCount 0
                                                                                       :scheduleTime ""
                                                                                       :view ""}}})
require "http/client"

url = "{{baseUrl}}/v2beta3/:parent/tasks"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v2beta3/:parent/tasks"),
    Content = new StringContent("{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v2beta3/:parent/tasks");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/v2beta3/:parent/tasks"

	payload := strings.NewReader("{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}")

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

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

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

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

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

}
POST /baseUrl/v2beta3/:parent/tasks HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1040

{
  "responseView": "",
  "task": {
    "appEngineHttpRequest": {
      "appEngineRouting": {
        "host": "",
        "instance": "",
        "service": "",
        "version": ""
      },
      "body": "",
      "headers": {},
      "httpMethod": "",
      "relativeUri": ""
    },
    "createTime": "",
    "dispatchCount": 0,
    "dispatchDeadline": "",
    "firstAttempt": {
      "dispatchTime": "",
      "responseStatus": {
        "code": 0,
        "details": [
          {}
        ],
        "message": ""
      },
      "responseTime": "",
      "scheduleTime": ""
    },
    "httpRequest": {
      "body": "",
      "headers": {},
      "httpMethod": "",
      "oauthToken": {
        "scope": "",
        "serviceAccountEmail": ""
      },
      "oidcToken": {
        "audience": "",
        "serviceAccountEmail": ""
      },
      "url": ""
    },
    "lastAttempt": {},
    "name": "",
    "pullMessage": {
      "payload": "",
      "tag": ""
    },
    "responseCount": 0,
    "scheduleTime": "",
    "view": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta3/:parent/tasks")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v2beta3/:parent/tasks"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta3/:parent/tasks")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta3/:parent/tasks")
  .header("content-type", "application/json")
  .body("{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  responseView: '',
  task: {
    appEngineHttpRequest: {
      appEngineRouting: {
        host: '',
        instance: '',
        service: '',
        version: ''
      },
      body: '',
      headers: {},
      httpMethod: '',
      relativeUri: ''
    },
    createTime: '',
    dispatchCount: 0,
    dispatchDeadline: '',
    firstAttempt: {
      dispatchTime: '',
      responseStatus: {
        code: 0,
        details: [
          {}
        ],
        message: ''
      },
      responseTime: '',
      scheduleTime: ''
    },
    httpRequest: {
      body: '',
      headers: {},
      httpMethod: '',
      oauthToken: {
        scope: '',
        serviceAccountEmail: ''
      },
      oidcToken: {
        audience: '',
        serviceAccountEmail: ''
      },
      url: ''
    },
    lastAttempt: {},
    name: '',
    pullMessage: {
      payload: '',
      tag: ''
    },
    responseCount: 0,
    scheduleTime: '',
    view: ''
  }
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:parent/tasks',
  headers: {'content-type': 'application/json'},
  data: {
    responseView: '',
    task: {
      appEngineHttpRequest: {
        appEngineRouting: {host: '', instance: '', service: '', version: ''},
        body: '',
        headers: {},
        httpMethod: '',
        relativeUri: ''
      },
      createTime: '',
      dispatchCount: 0,
      dispatchDeadline: '',
      firstAttempt: {
        dispatchTime: '',
        responseStatus: {code: 0, details: [{}], message: ''},
        responseTime: '',
        scheduleTime: ''
      },
      httpRequest: {
        body: '',
        headers: {},
        httpMethod: '',
        oauthToken: {scope: '', serviceAccountEmail: ''},
        oidcToken: {audience: '', serviceAccountEmail: ''},
        url: ''
      },
      lastAttempt: {},
      name: '',
      pullMessage: {payload: '', tag: ''},
      responseCount: 0,
      scheduleTime: '',
      view: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta3/:parent/tasks';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"responseView":"","task":{"appEngineHttpRequest":{"appEngineRouting":{"host":"","instance":"","service":"","version":""},"body":"","headers":{},"httpMethod":"","relativeUri":""},"createTime":"","dispatchCount":0,"dispatchDeadline":"","firstAttempt":{"dispatchTime":"","responseStatus":{"code":0,"details":[{}],"message":""},"responseTime":"","scheduleTime":""},"httpRequest":{"body":"","headers":{},"httpMethod":"","oauthToken":{"scope":"","serviceAccountEmail":""},"oidcToken":{"audience":"","serviceAccountEmail":""},"url":""},"lastAttempt":{},"name":"","pullMessage":{"payload":"","tag":""},"responseCount":0,"scheduleTime":"","view":""}}'
};

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}}/v2beta3/:parent/tasks',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "responseView": "",\n  "task": {\n    "appEngineHttpRequest": {\n      "appEngineRouting": {\n        "host": "",\n        "instance": "",\n        "service": "",\n        "version": ""\n      },\n      "body": "",\n      "headers": {},\n      "httpMethod": "",\n      "relativeUri": ""\n    },\n    "createTime": "",\n    "dispatchCount": 0,\n    "dispatchDeadline": "",\n    "firstAttempt": {\n      "dispatchTime": "",\n      "responseStatus": {\n        "code": 0,\n        "details": [\n          {}\n        ],\n        "message": ""\n      },\n      "responseTime": "",\n      "scheduleTime": ""\n    },\n    "httpRequest": {\n      "body": "",\n      "headers": {},\n      "httpMethod": "",\n      "oauthToken": {\n        "scope": "",\n        "serviceAccountEmail": ""\n      },\n      "oidcToken": {\n        "audience": "",\n        "serviceAccountEmail": ""\n      },\n      "url": ""\n    },\n    "lastAttempt": {},\n    "name": "",\n    "pullMessage": {\n      "payload": "",\n      "tag": ""\n    },\n    "responseCount": 0,\n    "scheduleTime": "",\n    "view": ""\n  }\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta3/:parent/tasks")
  .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/v2beta3/:parent/tasks',
  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({
  responseView: '',
  task: {
    appEngineHttpRequest: {
      appEngineRouting: {host: '', instance: '', service: '', version: ''},
      body: '',
      headers: {},
      httpMethod: '',
      relativeUri: ''
    },
    createTime: '',
    dispatchCount: 0,
    dispatchDeadline: '',
    firstAttempt: {
      dispatchTime: '',
      responseStatus: {code: 0, details: [{}], message: ''},
      responseTime: '',
      scheduleTime: ''
    },
    httpRequest: {
      body: '',
      headers: {},
      httpMethod: '',
      oauthToken: {scope: '', serviceAccountEmail: ''},
      oidcToken: {audience: '', serviceAccountEmail: ''},
      url: ''
    },
    lastAttempt: {},
    name: '',
    pullMessage: {payload: '', tag: ''},
    responseCount: 0,
    scheduleTime: '',
    view: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:parent/tasks',
  headers: {'content-type': 'application/json'},
  body: {
    responseView: '',
    task: {
      appEngineHttpRequest: {
        appEngineRouting: {host: '', instance: '', service: '', version: ''},
        body: '',
        headers: {},
        httpMethod: '',
        relativeUri: ''
      },
      createTime: '',
      dispatchCount: 0,
      dispatchDeadline: '',
      firstAttempt: {
        dispatchTime: '',
        responseStatus: {code: 0, details: [{}], message: ''},
        responseTime: '',
        scheduleTime: ''
      },
      httpRequest: {
        body: '',
        headers: {},
        httpMethod: '',
        oauthToken: {scope: '', serviceAccountEmail: ''},
        oidcToken: {audience: '', serviceAccountEmail: ''},
        url: ''
      },
      lastAttempt: {},
      name: '',
      pullMessage: {payload: '', tag: ''},
      responseCount: 0,
      scheduleTime: '',
      view: ''
    }
  },
  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}}/v2beta3/:parent/tasks');

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

req.type('json');
req.send({
  responseView: '',
  task: {
    appEngineHttpRequest: {
      appEngineRouting: {
        host: '',
        instance: '',
        service: '',
        version: ''
      },
      body: '',
      headers: {},
      httpMethod: '',
      relativeUri: ''
    },
    createTime: '',
    dispatchCount: 0,
    dispatchDeadline: '',
    firstAttempt: {
      dispatchTime: '',
      responseStatus: {
        code: 0,
        details: [
          {}
        ],
        message: ''
      },
      responseTime: '',
      scheduleTime: ''
    },
    httpRequest: {
      body: '',
      headers: {},
      httpMethod: '',
      oauthToken: {
        scope: '',
        serviceAccountEmail: ''
      },
      oidcToken: {
        audience: '',
        serviceAccountEmail: ''
      },
      url: ''
    },
    lastAttempt: {},
    name: '',
    pullMessage: {
      payload: '',
      tag: ''
    },
    responseCount: 0,
    scheduleTime: '',
    view: ''
  }
});

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}}/v2beta3/:parent/tasks',
  headers: {'content-type': 'application/json'},
  data: {
    responseView: '',
    task: {
      appEngineHttpRequest: {
        appEngineRouting: {host: '', instance: '', service: '', version: ''},
        body: '',
        headers: {},
        httpMethod: '',
        relativeUri: ''
      },
      createTime: '',
      dispatchCount: 0,
      dispatchDeadline: '',
      firstAttempt: {
        dispatchTime: '',
        responseStatus: {code: 0, details: [{}], message: ''},
        responseTime: '',
        scheduleTime: ''
      },
      httpRequest: {
        body: '',
        headers: {},
        httpMethod: '',
        oauthToken: {scope: '', serviceAccountEmail: ''},
        oidcToken: {audience: '', serviceAccountEmail: ''},
        url: ''
      },
      lastAttempt: {},
      name: '',
      pullMessage: {payload: '', tag: ''},
      responseCount: 0,
      scheduleTime: '',
      view: ''
    }
  }
};

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

const url = '{{baseUrl}}/v2beta3/:parent/tasks';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"responseView":"","task":{"appEngineHttpRequest":{"appEngineRouting":{"host":"","instance":"","service":"","version":""},"body":"","headers":{},"httpMethod":"","relativeUri":""},"createTime":"","dispatchCount":0,"dispatchDeadline":"","firstAttempt":{"dispatchTime":"","responseStatus":{"code":0,"details":[{}],"message":""},"responseTime":"","scheduleTime":""},"httpRequest":{"body":"","headers":{},"httpMethod":"","oauthToken":{"scope":"","serviceAccountEmail":""},"oidcToken":{"audience":"","serviceAccountEmail":""},"url":""},"lastAttempt":{},"name":"","pullMessage":{"payload":"","tag":""},"responseCount":0,"scheduleTime":"","view":""}}'
};

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 = @{ @"responseView": @"",
                              @"task": @{ @"appEngineHttpRequest": @{ @"appEngineRouting": @{ @"host": @"", @"instance": @"", @"service": @"", @"version": @"" }, @"body": @"", @"headers": @{  }, @"httpMethod": @"", @"relativeUri": @"" }, @"createTime": @"", @"dispatchCount": @0, @"dispatchDeadline": @"", @"firstAttempt": @{ @"dispatchTime": @"", @"responseStatus": @{ @"code": @0, @"details": @[ @{  } ], @"message": @"" }, @"responseTime": @"", @"scheduleTime": @"" }, @"httpRequest": @{ @"body": @"", @"headers": @{  }, @"httpMethod": @"", @"oauthToken": @{ @"scope": @"", @"serviceAccountEmail": @"" }, @"oidcToken": @{ @"audience": @"", @"serviceAccountEmail": @"" }, @"url": @"" }, @"lastAttempt": @{  }, @"name": @"", @"pullMessage": @{ @"payload": @"", @"tag": @"" }, @"responseCount": @0, @"scheduleTime": @"", @"view": @"" } };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v2beta3/:parent/tasks"]
                                                       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}}/v2beta3/:parent/tasks" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v2beta3/:parent/tasks",
  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([
    'responseView' => '',
    'task' => [
        'appEngineHttpRequest' => [
                'appEngineRouting' => [
                                'host' => '',
                                'instance' => '',
                                'service' => '',
                                'version' => ''
                ],
                'body' => '',
                'headers' => [
                                
                ],
                'httpMethod' => '',
                'relativeUri' => ''
        ],
        'createTime' => '',
        'dispatchCount' => 0,
        'dispatchDeadline' => '',
        'firstAttempt' => [
                'dispatchTime' => '',
                'responseStatus' => [
                                'code' => 0,
                                'details' => [
                                                                [
                                                                                                                                
                                                                ]
                                ],
                                'message' => ''
                ],
                'responseTime' => '',
                'scheduleTime' => ''
        ],
        'httpRequest' => [
                'body' => '',
                'headers' => [
                                
                ],
                'httpMethod' => '',
                'oauthToken' => [
                                'scope' => '',
                                'serviceAccountEmail' => ''
                ],
                'oidcToken' => [
                                'audience' => '',
                                'serviceAccountEmail' => ''
                ],
                'url' => ''
        ],
        'lastAttempt' => [
                
        ],
        'name' => '',
        'pullMessage' => [
                'payload' => '',
                'tag' => ''
        ],
        'responseCount' => 0,
        'scheduleTime' => '',
        'view' => ''
    ]
  ]),
  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}}/v2beta3/:parent/tasks', [
  'body' => '{
  "responseView": "",
  "task": {
    "appEngineHttpRequest": {
      "appEngineRouting": {
        "host": "",
        "instance": "",
        "service": "",
        "version": ""
      },
      "body": "",
      "headers": {},
      "httpMethod": "",
      "relativeUri": ""
    },
    "createTime": "",
    "dispatchCount": 0,
    "dispatchDeadline": "",
    "firstAttempt": {
      "dispatchTime": "",
      "responseStatus": {
        "code": 0,
        "details": [
          {}
        ],
        "message": ""
      },
      "responseTime": "",
      "scheduleTime": ""
    },
    "httpRequest": {
      "body": "",
      "headers": {},
      "httpMethod": "",
      "oauthToken": {
        "scope": "",
        "serviceAccountEmail": ""
      },
      "oidcToken": {
        "audience": "",
        "serviceAccountEmail": ""
      },
      "url": ""
    },
    "lastAttempt": {},
    "name": "",
    "pullMessage": {
      "payload": "",
      "tag": ""
    },
    "responseCount": 0,
    "scheduleTime": "",
    "view": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'responseView' => '',
  'task' => [
    'appEngineHttpRequest' => [
        'appEngineRouting' => [
                'host' => '',
                'instance' => '',
                'service' => '',
                'version' => ''
        ],
        'body' => '',
        'headers' => [
                
        ],
        'httpMethod' => '',
        'relativeUri' => ''
    ],
    'createTime' => '',
    'dispatchCount' => 0,
    'dispatchDeadline' => '',
    'firstAttempt' => [
        'dispatchTime' => '',
        'responseStatus' => [
                'code' => 0,
                'details' => [
                                [
                                                                
                                ]
                ],
                'message' => ''
        ],
        'responseTime' => '',
        'scheduleTime' => ''
    ],
    'httpRequest' => [
        'body' => '',
        'headers' => [
                
        ],
        'httpMethod' => '',
        'oauthToken' => [
                'scope' => '',
                'serviceAccountEmail' => ''
        ],
        'oidcToken' => [
                'audience' => '',
                'serviceAccountEmail' => ''
        ],
        'url' => ''
    ],
    'lastAttempt' => [
        
    ],
    'name' => '',
    'pullMessage' => [
        'payload' => '',
        'tag' => ''
    ],
    'responseCount' => 0,
    'scheduleTime' => '',
    'view' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'responseView' => '',
  'task' => [
    'appEngineHttpRequest' => [
        'appEngineRouting' => [
                'host' => '',
                'instance' => '',
                'service' => '',
                'version' => ''
        ],
        'body' => '',
        'headers' => [
                
        ],
        'httpMethod' => '',
        'relativeUri' => ''
    ],
    'createTime' => '',
    'dispatchCount' => 0,
    'dispatchDeadline' => '',
    'firstAttempt' => [
        'dispatchTime' => '',
        'responseStatus' => [
                'code' => 0,
                'details' => [
                                [
                                                                
                                ]
                ],
                'message' => ''
        ],
        'responseTime' => '',
        'scheduleTime' => ''
    ],
    'httpRequest' => [
        'body' => '',
        'headers' => [
                
        ],
        'httpMethod' => '',
        'oauthToken' => [
                'scope' => '',
                'serviceAccountEmail' => ''
        ],
        'oidcToken' => [
                'audience' => '',
                'serviceAccountEmail' => ''
        ],
        'url' => ''
    ],
    'lastAttempt' => [
        
    ],
    'name' => '',
    'pullMessage' => [
        'payload' => '',
        'tag' => ''
    ],
    'responseCount' => 0,
    'scheduleTime' => '',
    'view' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v2beta3/:parent/tasks');
$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}}/v2beta3/:parent/tasks' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "responseView": "",
  "task": {
    "appEngineHttpRequest": {
      "appEngineRouting": {
        "host": "",
        "instance": "",
        "service": "",
        "version": ""
      },
      "body": "",
      "headers": {},
      "httpMethod": "",
      "relativeUri": ""
    },
    "createTime": "",
    "dispatchCount": 0,
    "dispatchDeadline": "",
    "firstAttempt": {
      "dispatchTime": "",
      "responseStatus": {
        "code": 0,
        "details": [
          {}
        ],
        "message": ""
      },
      "responseTime": "",
      "scheduleTime": ""
    },
    "httpRequest": {
      "body": "",
      "headers": {},
      "httpMethod": "",
      "oauthToken": {
        "scope": "",
        "serviceAccountEmail": ""
      },
      "oidcToken": {
        "audience": "",
        "serviceAccountEmail": ""
      },
      "url": ""
    },
    "lastAttempt": {},
    "name": "",
    "pullMessage": {
      "payload": "",
      "tag": ""
    },
    "responseCount": 0,
    "scheduleTime": "",
    "view": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v2beta3/:parent/tasks' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "responseView": "",
  "task": {
    "appEngineHttpRequest": {
      "appEngineRouting": {
        "host": "",
        "instance": "",
        "service": "",
        "version": ""
      },
      "body": "",
      "headers": {},
      "httpMethod": "",
      "relativeUri": ""
    },
    "createTime": "",
    "dispatchCount": 0,
    "dispatchDeadline": "",
    "firstAttempt": {
      "dispatchTime": "",
      "responseStatus": {
        "code": 0,
        "details": [
          {}
        ],
        "message": ""
      },
      "responseTime": "",
      "scheduleTime": ""
    },
    "httpRequest": {
      "body": "",
      "headers": {},
      "httpMethod": "",
      "oauthToken": {
        "scope": "",
        "serviceAccountEmail": ""
      },
      "oidcToken": {
        "audience": "",
        "serviceAccountEmail": ""
      },
      "url": ""
    },
    "lastAttempt": {},
    "name": "",
    "pullMessage": {
      "payload": "",
      "tag": ""
    },
    "responseCount": 0,
    "scheduleTime": "",
    "view": ""
  }
}'
import http.client

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

payload = "{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}"

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

conn.request("POST", "/baseUrl/v2beta3/:parent/tasks", payload, headers)

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

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

url = "{{baseUrl}}/v2beta3/:parent/tasks"

payload = {
    "responseView": "",
    "task": {
        "appEngineHttpRequest": {
            "appEngineRouting": {
                "host": "",
                "instance": "",
                "service": "",
                "version": ""
            },
            "body": "",
            "headers": {},
            "httpMethod": "",
            "relativeUri": ""
        },
        "createTime": "",
        "dispatchCount": 0,
        "dispatchDeadline": "",
        "firstAttempt": {
            "dispatchTime": "",
            "responseStatus": {
                "code": 0,
                "details": [{}],
                "message": ""
            },
            "responseTime": "",
            "scheduleTime": ""
        },
        "httpRequest": {
            "body": "",
            "headers": {},
            "httpMethod": "",
            "oauthToken": {
                "scope": "",
                "serviceAccountEmail": ""
            },
            "oidcToken": {
                "audience": "",
                "serviceAccountEmail": ""
            },
            "url": ""
        },
        "lastAttempt": {},
        "name": "",
        "pullMessage": {
            "payload": "",
            "tag": ""
        },
        "responseCount": 0,
        "scheduleTime": "",
        "view": ""
    }
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v2beta3/:parent/tasks"

payload <- "{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v2beta3/:parent/tasks")

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  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}"

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

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

response = conn.post('/baseUrl/v2beta3/:parent/tasks') do |req|
  req.body = "{\n  \"responseView\": \"\",\n  \"task\": {\n    \"appEngineHttpRequest\": {\n      \"appEngineRouting\": {\n        \"host\": \"\",\n        \"instance\": \"\",\n        \"service\": \"\",\n        \"version\": \"\"\n      },\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"relativeUri\": \"\"\n    },\n    \"createTime\": \"\",\n    \"dispatchCount\": 0,\n    \"dispatchDeadline\": \"\",\n    \"firstAttempt\": {\n      \"dispatchTime\": \"\",\n      \"responseStatus\": {\n        \"code\": 0,\n        \"details\": [\n          {}\n        ],\n        \"message\": \"\"\n      },\n      \"responseTime\": \"\",\n      \"scheduleTime\": \"\"\n    },\n    \"httpRequest\": {\n      \"body\": \"\",\n      \"headers\": {},\n      \"httpMethod\": \"\",\n      \"oauthToken\": {\n        \"scope\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"oidcToken\": {\n        \"audience\": \"\",\n        \"serviceAccountEmail\": \"\"\n      },\n      \"url\": \"\"\n    },\n    \"lastAttempt\": {},\n    \"name\": \"\",\n    \"pullMessage\": {\n      \"payload\": \"\",\n      \"tag\": \"\"\n    },\n    \"responseCount\": 0,\n    \"scheduleTime\": \"\",\n    \"view\": \"\"\n  }\n}"
end

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

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

    let payload = json!({
        "responseView": "",
        "task": json!({
            "appEngineHttpRequest": json!({
                "appEngineRouting": json!({
                    "host": "",
                    "instance": "",
                    "service": "",
                    "version": ""
                }),
                "body": "",
                "headers": json!({}),
                "httpMethod": "",
                "relativeUri": ""
            }),
            "createTime": "",
            "dispatchCount": 0,
            "dispatchDeadline": "",
            "firstAttempt": json!({
                "dispatchTime": "",
                "responseStatus": json!({
                    "code": 0,
                    "details": (json!({})),
                    "message": ""
                }),
                "responseTime": "",
                "scheduleTime": ""
            }),
            "httpRequest": json!({
                "body": "",
                "headers": json!({}),
                "httpMethod": "",
                "oauthToken": json!({
                    "scope": "",
                    "serviceAccountEmail": ""
                }),
                "oidcToken": json!({
                    "audience": "",
                    "serviceAccountEmail": ""
                }),
                "url": ""
            }),
            "lastAttempt": json!({}),
            "name": "",
            "pullMessage": json!({
                "payload": "",
                "tag": ""
            }),
            "responseCount": 0,
            "scheduleTime": "",
            "view": ""
        })
    });

    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}}/v2beta3/:parent/tasks \
  --header 'content-type: application/json' \
  --data '{
  "responseView": "",
  "task": {
    "appEngineHttpRequest": {
      "appEngineRouting": {
        "host": "",
        "instance": "",
        "service": "",
        "version": ""
      },
      "body": "",
      "headers": {},
      "httpMethod": "",
      "relativeUri": ""
    },
    "createTime": "",
    "dispatchCount": 0,
    "dispatchDeadline": "",
    "firstAttempt": {
      "dispatchTime": "",
      "responseStatus": {
        "code": 0,
        "details": [
          {}
        ],
        "message": ""
      },
      "responseTime": "",
      "scheduleTime": ""
    },
    "httpRequest": {
      "body": "",
      "headers": {},
      "httpMethod": "",
      "oauthToken": {
        "scope": "",
        "serviceAccountEmail": ""
      },
      "oidcToken": {
        "audience": "",
        "serviceAccountEmail": ""
      },
      "url": ""
    },
    "lastAttempt": {},
    "name": "",
    "pullMessage": {
      "payload": "",
      "tag": ""
    },
    "responseCount": 0,
    "scheduleTime": "",
    "view": ""
  }
}'
echo '{
  "responseView": "",
  "task": {
    "appEngineHttpRequest": {
      "appEngineRouting": {
        "host": "",
        "instance": "",
        "service": "",
        "version": ""
      },
      "body": "",
      "headers": {},
      "httpMethod": "",
      "relativeUri": ""
    },
    "createTime": "",
    "dispatchCount": 0,
    "dispatchDeadline": "",
    "firstAttempt": {
      "dispatchTime": "",
      "responseStatus": {
        "code": 0,
        "details": [
          {}
        ],
        "message": ""
      },
      "responseTime": "",
      "scheduleTime": ""
    },
    "httpRequest": {
      "body": "",
      "headers": {},
      "httpMethod": "",
      "oauthToken": {
        "scope": "",
        "serviceAccountEmail": ""
      },
      "oidcToken": {
        "audience": "",
        "serviceAccountEmail": ""
      },
      "url": ""
    },
    "lastAttempt": {},
    "name": "",
    "pullMessage": {
      "payload": "",
      "tag": ""
    },
    "responseCount": 0,
    "scheduleTime": "",
    "view": ""
  }
}' |  \
  http POST {{baseUrl}}/v2beta3/:parent/tasks \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "responseView": "",\n  "task": {\n    "appEngineHttpRequest": {\n      "appEngineRouting": {\n        "host": "",\n        "instance": "",\n        "service": "",\n        "version": ""\n      },\n      "body": "",\n      "headers": {},\n      "httpMethod": "",\n      "relativeUri": ""\n    },\n    "createTime": "",\n    "dispatchCount": 0,\n    "dispatchDeadline": "",\n    "firstAttempt": {\n      "dispatchTime": "",\n      "responseStatus": {\n        "code": 0,\n        "details": [\n          {}\n        ],\n        "message": ""\n      },\n      "responseTime": "",\n      "scheduleTime": ""\n    },\n    "httpRequest": {\n      "body": "",\n      "headers": {},\n      "httpMethod": "",\n      "oauthToken": {\n        "scope": "",\n        "serviceAccountEmail": ""\n      },\n      "oidcToken": {\n        "audience": "",\n        "serviceAccountEmail": ""\n      },\n      "url": ""\n    },\n    "lastAttempt": {},\n    "name": "",\n    "pullMessage": {\n      "payload": "",\n      "tag": ""\n    },\n    "responseCount": 0,\n    "scheduleTime": "",\n    "view": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v2beta3/:parent/tasks
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "responseView": "",
  "task": [
    "appEngineHttpRequest": [
      "appEngineRouting": [
        "host": "",
        "instance": "",
        "service": "",
        "version": ""
      ],
      "body": "",
      "headers": [],
      "httpMethod": "",
      "relativeUri": ""
    ],
    "createTime": "",
    "dispatchCount": 0,
    "dispatchDeadline": "",
    "firstAttempt": [
      "dispatchTime": "",
      "responseStatus": [
        "code": 0,
        "details": [[]],
        "message": ""
      ],
      "responseTime": "",
      "scheduleTime": ""
    ],
    "httpRequest": [
      "body": "",
      "headers": [],
      "httpMethod": "",
      "oauthToken": [
        "scope": "",
        "serviceAccountEmail": ""
      ],
      "oidcToken": [
        "audience": "",
        "serviceAccountEmail": ""
      ],
      "url": ""
    ],
    "lastAttempt": [],
    "name": "",
    "pullMessage": [
      "payload": "",
      "tag": ""
    ],
    "responseCount": 0,
    "scheduleTime": "",
    "view": ""
  ]
] as [String : Any]

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

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

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

dataTask.resume()
DELETE cloudtasks.projects.locations.queues.tasks.delete
{{baseUrl}}/v2beta3/:name
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

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

func main() {

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

curl_close($curl);

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

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

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

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

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

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

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

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

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

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

response = requests.delete(url)

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

dataTask.resume()
GET cloudtasks.projects.locations.queues.tasks.get
{{baseUrl}}/v2beta3/: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}}/v2beta3/:name");

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

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

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

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

func main() {

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

response = requests.get(url)

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

(client/get "{{baseUrl}}/v2beta3/:parent/tasks")
require "http/client"

url = "{{baseUrl}}/v2beta3/:parent/tasks"

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

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

func main() {

	url := "{{baseUrl}}/v2beta3/:parent/tasks"

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

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

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

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

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

const options = {method: 'GET', url: '{{baseUrl}}/v2beta3/:parent/tasks'};

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

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

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

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

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

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

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

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

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}}/v2beta3/:parent/tasks'};

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/v2beta3/:parent/tasks")

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

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

url = "{{baseUrl}}/v2beta3/:parent/tasks"

response = requests.get(url)

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

url <- "{{baseUrl}}/v2beta3/:parent/tasks"

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

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

url = URI("{{baseUrl}}/v2beta3/:parent/tasks")

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

puts response.status
puts response.body
use reqwest;

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta3/:parent/tasks")! 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 cloudtasks.projects.locations.queues.tasks.run
{{baseUrl}}/v2beta3/:name:run
QUERY PARAMS

name
BODY json

{
  "responseView": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta3/:name: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  \"responseView\": \"\"\n}");

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

(client/post "{{baseUrl}}/v2beta3/:name:run" {:content-type :json
                                                              :form-params {:responseView ""}})
require "http/client"

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

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

func main() {

	url := "{{baseUrl}}/v2beta3/:name:run"

	payload := strings.NewReader("{\n  \"responseView\": \"\"\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/v2beta3/:name:run HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 24

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

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

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

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

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

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

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

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

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

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}}/v2beta3/:name:run',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "responseView": ""\n}'
};

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:name:run',
  headers: {'content-type': 'application/json'},
  body: {responseView: ''},
  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}}/v2beta3/:name:run');

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

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

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}}/v2beta3/:name:run',
  headers: {'content-type': 'application/json'},
  data: {responseView: ''}
};

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

const url = '{{baseUrl}}/v2beta3/:name:run';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"responseView":""}'
};

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 = @{ @"responseView": @"" };

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

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

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

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

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

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

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

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

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

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

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

conn.request("POST", "/baseUrl/v2beta3/:name:run", payload, headers)

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

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

url = "{{baseUrl}}/v2beta3/:name:run"

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

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

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

url <- "{{baseUrl}}/v2beta3/:name:run"

payload <- "{\n  \"responseView\": \"\"\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}}/v2beta3/:name: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  \"responseView\": \"\"\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/v2beta3/:name:run') do |req|
  req.body = "{\n  \"responseView\": \"\"\n}"
end

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

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

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

    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}}/v2beta3/:name:run \
  --header 'content-type: application/json' \
  --data '{
  "responseView": ""
}'
echo '{
  "responseView": ""
}' |  \
  http POST {{baseUrl}}/v2beta3/:name:run \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "responseView": ""\n}' \
  --output-document \
  - {{baseUrl}}/v2beta3/:name:run
import Foundation

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v2beta3/:name: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()
POST cloudtasks.projects.locations.queues.testIamPermissions
{{baseUrl}}/v2beta3/:resource:testIamPermissions
QUERY PARAMS

resource
BODY json

{
  "permissions": []
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v2beta3/:resource:testIamPermissions");

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"permissions\": []\n}");

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

(client/post "{{baseUrl}}/v2beta3/:resource:testIamPermissions" {:content-type :json
                                                                                 :form-params {:permissions []}})
require "http/client"

url = "{{baseUrl}}/v2beta3/:resource:testIamPermissions"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"permissions\": []\n}"

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

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

func main() {

	url := "{{baseUrl}}/v2beta3/:resource:testIamPermissions"

	payload := strings.NewReader("{\n  \"permissions\": []\n}")

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

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

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

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

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

}
POST /baseUrl/v2beta3/:resource:testIamPermissions HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 23

{
  "permissions": []
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v2beta3/:resource:testIamPermissions")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"permissions\": []\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

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

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"permissions\": []\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v2beta3/:resource:testIamPermissions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v2beta3/:resource:testIamPermissions")
  .header("content-type", "application/json")
  .body("{\n  \"permissions\": []\n}")
  .asString();
const data = JSON.stringify({
  permissions: []
});

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

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

xhr.open('POST', '{{baseUrl}}/v2beta3/:resource:testIamPermissions');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:resource:testIamPermissions',
  headers: {'content-type': 'application/json'},
  data: {permissions: []}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v2beta3/:resource:testIamPermissions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"permissions":[]}'
};

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

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"permissions\": []\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v2beta3/:resource:testIamPermissions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

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

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:resource:testIamPermissions',
  headers: {'content-type': 'application/json'},
  body: {permissions: []},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v2beta3/:resource:testIamPermissions');

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

req.type('json');
req.send({
  permissions: []
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v2beta3/:resource:testIamPermissions',
  headers: {'content-type': 'application/json'},
  data: {permissions: []}
};

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

const url = '{{baseUrl}}/v2beta3/:resource:testIamPermissions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"permissions":[]}'
};

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

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

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v2beta3/:resource:testIamPermissions" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"permissions\": []\n}" in

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

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

curl_close($curl);

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

echo $response->getBody();
setUrl('{{baseUrl}}/v2beta3/:resource:testIamPermissions');
$request->setMethod(HTTP_METH_POST);

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

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

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'permissions' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v2beta3/:resource:testIamPermissions');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

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

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

payload = "{\n  \"permissions\": []\n}"

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

conn.request("POST", "/baseUrl/v2beta3/:resource:testIamPermissions", payload, headers)

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

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

url = "{{baseUrl}}/v2beta3/:resource:testIamPermissions"

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

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

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

url <- "{{baseUrl}}/v2beta3/:resource:testIamPermissions"

payload <- "{\n  \"permissions\": []\n}"

encode <- "json"

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

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

url = URI("{{baseUrl}}/v2beta3/:resource:testIamPermissions")

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

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

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

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

response = conn.post('/baseUrl/v2beta3/:resource:testIamPermissions') do |req|
  req.body = "{\n  \"permissions\": []\n}"
end

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

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

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

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v2beta3/:resource:testIamPermissions \
  --header 'content-type: application/json' \
  --data '{
  "permissions": []
}'
echo '{
  "permissions": []
}' |  \
  http POST {{baseUrl}}/v2beta3/:resource:testIamPermissions \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "permissions": []\n}' \
  --output-document \
  - {{baseUrl}}/v2beta3/:resource:testIamPermissions
import Foundation

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

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

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

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

dataTask.resume()