POST firebasehosting.projects.sites.create
{{baseUrl}}/v1beta1/:parent/sites
QUERY PARAMS

parent
BODY json

{
  "appId": "",
  "defaultUrl": "",
  "labels": {},
  "name": "",
  "type": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"appId\": \"\",\n  \"defaultUrl\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"type\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:parent/sites" {:content-type :json
                                                                  :form-params {:appId ""
                                                                                :defaultUrl ""
                                                                                :labels {}
                                                                                :name ""
                                                                                :type ""}})
require "http/client"

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

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

func main() {

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

	payload := strings.NewReader("{\n  \"appId\": \"\",\n  \"defaultUrl\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\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/v1beta1/:parent/sites HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 81

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

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

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:parent/sites")
  .header("content-type", "application/json")
  .body("{\n  \"appId\": \"\",\n  \"defaultUrl\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"type\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  appId: '',
  defaultUrl: '',
  labels: {},
  name: '',
  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}}/v1beta1/:parent/sites');
xhr.setRequestHeader('content-type', 'application/json');

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/sites',
  headers: {'content-type': 'application/json'},
  data: {appId: '', defaultUrl: '', labels: {}, name: '', type: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent/sites';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appId":"","defaultUrl":"","labels":{},"name":"","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}}/v1beta1/:parent/sites',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "appId": "",\n  "defaultUrl": "",\n  "labels": {},\n  "name": "",\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  \"appId\": \"\",\n  \"defaultUrl\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"type\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/sites")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/:parent/sites',
  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({appId: '', defaultUrl: '', labels: {}, name: '', type: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/sites',
  headers: {'content-type': 'application/json'},
  body: {appId: '', defaultUrl: '', labels: {}, name: '', 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}}/v1beta1/:parent/sites');

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

req.type('json');
req.send({
  appId: '',
  defaultUrl: '',
  labels: {},
  name: '',
  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}}/v1beta1/:parent/sites',
  headers: {'content-type': 'application/json'},
  data: {appId: '', defaultUrl: '', labels: {}, name: '', type: ''}
};

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

const url = '{{baseUrl}}/v1beta1/:parent/sites';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"appId":"","defaultUrl":"","labels":{},"name":"","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 = @{ @"appId": @"",
                              @"defaultUrl": @"",
                              @"labels": @{  },
                              @"name": @"",
                              @"type": @"" };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:parent/sites" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"appId\": \"\",\n  \"defaultUrl\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"type\": \"\"\n}" in

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

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'appId' => '',
  'defaultUrl' => '',
  'labels' => [
    
  ],
  'name' => '',
  'type' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'appId' => '',
  'defaultUrl' => '',
  'labels' => [
    
  ],
  'name' => '',
  'type' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:parent/sites');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

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

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

payload = "{\n  \"appId\": \"\",\n  \"defaultUrl\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"type\": \"\"\n}"

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

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

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

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

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

payload = {
    "appId": "",
    "defaultUrl": "",
    "labels": {},
    "name": "",
    "type": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"appId\": \"\",\n  \"defaultUrl\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\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}}/v1beta1/:parent/sites")

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  \"appId\": \"\",\n  \"defaultUrl\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\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/v1beta1/:parent/sites') do |req|
  req.body = "{\n  \"appId\": \"\",\n  \"defaultUrl\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\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}}/v1beta1/:parent/sites";

    let payload = json!({
        "appId": "",
        "defaultUrl": "",
        "labels": json!({}),
        "name": "",
        "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}}/v1beta1/:parent/sites \
  --header 'content-type: application/json' \
  --data '{
  "appId": "",
  "defaultUrl": "",
  "labels": {},
  "name": "",
  "type": ""
}'
echo '{
  "appId": "",
  "defaultUrl": "",
  "labels": {},
  "name": "",
  "type": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:parent/sites \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "appId": "",\n  "defaultUrl": "",\n  "labels": {},\n  "name": "",\n  "type": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/sites
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "appId": "",
  "defaultUrl": "",
  "labels": [],
  "name": "",
  "type": ""
] as [String : Any]

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

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

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

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

func main() {

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

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

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

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

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

}
GET /baseUrl/v1beta1/:parent/sites HTTP/1.1
Host: example.com

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

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

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

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

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

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

xhr.open('GET', '{{baseUrl}}/v1beta1/:parent/sites');

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

curl_close($curl);

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

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

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

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

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

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

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

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

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

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

response = requests.get(url)

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

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

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

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

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

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/sites")! 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 firebasehosting.sites.channels.create
{{baseUrl}}/v1beta1/:parent/channels
QUERY PARAMS

parent
BODY json

{
  "createTime": "",
  "expireTime": "",
  "labels": {},
  "name": "",
  "release": {
    "message": "",
    "name": "",
    "releaseTime": "",
    "releaseUser": {
      "email": "",
      "imageUrl": ""
    },
    "type": "",
    "version": {
      "config": {
        "appAssociation": "",
        "cleanUrls": false,
        "headers": [
          {
            "glob": "",
            "headers": {},
            "regex": ""
          }
        ],
        "i18n": {
          "root": ""
        },
        "redirects": [
          {
            "glob": "",
            "location": "",
            "regex": "",
            "statusCode": 0
          }
        ],
        "rewrites": [
          {
            "dynamicLinks": false,
            "function": "",
            "functionRegion": "",
            "glob": "",
            "path": "",
            "regex": "",
            "run": {
              "region": "",
              "serviceId": ""
            }
          }
        ],
        "trailingSlashBehavior": ""
      },
      "createTime": "",
      "createUser": {},
      "deleteTime": "",
      "deleteUser": {},
      "fileCount": "",
      "finalizeTime": "",
      "finalizeUser": {},
      "labels": {},
      "name": "",
      "status": "",
      "versionBytes": ""
    }
  },
  "retainedReleaseCount": 0,
  "ttl": "",
  "updateTime": "",
  "url": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:parent/channels" {:content-type :json
                                                                     :form-params {:createTime ""
                                                                                   :expireTime ""
                                                                                   :labels {}
                                                                                   :name ""
                                                                                   :release {:message ""
                                                                                             :name ""
                                                                                             :releaseTime ""
                                                                                             :releaseUser {:email ""
                                                                                                           :imageUrl ""}
                                                                                             :type ""
                                                                                             :version {:config {:appAssociation ""
                                                                                                                :cleanUrls false
                                                                                                                :headers [{:glob ""
                                                                                                                           :headers {}
                                                                                                                           :regex ""}]
                                                                                                                :i18n {:root ""}
                                                                                                                :redirects [{:glob ""
                                                                                                                             :location ""
                                                                                                                             :regex ""
                                                                                                                             :statusCode 0}]
                                                                                                                :rewrites [{:dynamicLinks false
                                                                                                                            :function ""
                                                                                                                            :functionRegion ""
                                                                                                                            :glob ""
                                                                                                                            :path ""
                                                                                                                            :regex ""
                                                                                                                            :run {:region ""
                                                                                                                                  :serviceId ""}}]
                                                                                                                :trailingSlashBehavior ""}
                                                                                                       :createTime ""
                                                                                                       :createUser {}
                                                                                                       :deleteTime ""
                                                                                                       :deleteUser {}
                                                                                                       :fileCount ""
                                                                                                       :finalizeTime ""
                                                                                                       :finalizeUser {}
                                                                                                       :labels {}
                                                                                                       :name ""
                                                                                                       :status ""
                                                                                                       :versionBytes ""}}
                                                                                   :retainedReleaseCount 0
                                                                                   :ttl ""
                                                                                   :updateTime ""
                                                                                   :url ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/channels"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1beta1/:parent/channels"),
    Content = new StringContent("{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/:parent/channels");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}")

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

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

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

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

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

}
POST /baseUrl/v1beta1/:parent/channels HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1371

{
  "createTime": "",
  "expireTime": "",
  "labels": {},
  "name": "",
  "release": {
    "message": "",
    "name": "",
    "releaseTime": "",
    "releaseUser": {
      "email": "",
      "imageUrl": ""
    },
    "type": "",
    "version": {
      "config": {
        "appAssociation": "",
        "cleanUrls": false,
        "headers": [
          {
            "glob": "",
            "headers": {},
            "regex": ""
          }
        ],
        "i18n": {
          "root": ""
        },
        "redirects": [
          {
            "glob": "",
            "location": "",
            "regex": "",
            "statusCode": 0
          }
        ],
        "rewrites": [
          {
            "dynamicLinks": false,
            "function": "",
            "functionRegion": "",
            "glob": "",
            "path": "",
            "regex": "",
            "run": {
              "region": "",
              "serviceId": ""
            }
          }
        ],
        "trailingSlashBehavior": ""
      },
      "createTime": "",
      "createUser": {},
      "deleteTime": "",
      "deleteUser": {},
      "fileCount": "",
      "finalizeTime": "",
      "finalizeUser": {},
      "labels": {},
      "name": "",
      "status": "",
      "versionBytes": ""
    }
  },
  "retainedReleaseCount": 0,
  "ttl": "",
  "updateTime": "",
  "url": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:parent/channels")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:parent/channels"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}"))
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

MediaType mediaType = MediaType.parse("application/json");
RequestBody body = RequestBody.create(mediaType, "{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/channels")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:parent/channels")
  .header("content-type", "application/json")
  .body("{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  createTime: '',
  expireTime: '',
  labels: {},
  name: '',
  release: {
    message: '',
    name: '',
    releaseTime: '',
    releaseUser: {
      email: '',
      imageUrl: ''
    },
    type: '',
    version: {
      config: {
        appAssociation: '',
        cleanUrls: false,
        headers: [
          {
            glob: '',
            headers: {},
            regex: ''
          }
        ],
        i18n: {
          root: ''
        },
        redirects: [
          {
            glob: '',
            location: '',
            regex: '',
            statusCode: 0
          }
        ],
        rewrites: [
          {
            dynamicLinks: false,
            function: '',
            functionRegion: '',
            glob: '',
            path: '',
            regex: '',
            run: {
              region: '',
              serviceId: ''
            }
          }
        ],
        trailingSlashBehavior: ''
      },
      createTime: '',
      createUser: {},
      deleteTime: '',
      deleteUser: {},
      fileCount: '',
      finalizeTime: '',
      finalizeUser: {},
      labels: {},
      name: '',
      status: '',
      versionBytes: ''
    }
  },
  retainedReleaseCount: 0,
  ttl: '',
  updateTime: '',
  url: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/channels',
  headers: {'content-type': 'application/json'},
  data: {
    createTime: '',
    expireTime: '',
    labels: {},
    name: '',
    release: {
      message: '',
      name: '',
      releaseTime: '',
      releaseUser: {email: '', imageUrl: ''},
      type: '',
      version: {
        config: {
          appAssociation: '',
          cleanUrls: false,
          headers: [{glob: '', headers: {}, regex: ''}],
          i18n: {root: ''},
          redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
          rewrites: [
            {
              dynamicLinks: false,
              function: '',
              functionRegion: '',
              glob: '',
              path: '',
              regex: '',
              run: {region: '', serviceId: ''}
            }
          ],
          trailingSlashBehavior: ''
        },
        createTime: '',
        createUser: {},
        deleteTime: '',
        deleteUser: {},
        fileCount: '',
        finalizeTime: '',
        finalizeUser: {},
        labels: {},
        name: '',
        status: '',
        versionBytes: ''
      }
    },
    retainedReleaseCount: 0,
    ttl: '',
    updateTime: '',
    url: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent/channels';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"createTime":"","expireTime":"","labels":{},"name":"","release":{"message":"","name":"","releaseTime":"","releaseUser":{"email":"","imageUrl":""},"type":"","version":{"config":{"appAssociation":"","cleanUrls":false,"headers":[{"glob":"","headers":{},"regex":""}],"i18n":{"root":""},"redirects":[{"glob":"","location":"","regex":"","statusCode":0}],"rewrites":[{"dynamicLinks":false,"function":"","functionRegion":"","glob":"","path":"","regex":"","run":{"region":"","serviceId":""}}],"trailingSlashBehavior":""},"createTime":"","createUser":{},"deleteTime":"","deleteUser":{},"fileCount":"","finalizeTime":"","finalizeUser":{},"labels":{},"name":"","status":"","versionBytes":""}},"retainedReleaseCount":0,"ttl":"","updateTime":"","url":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:parent/channels',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "createTime": "",\n  "expireTime": "",\n  "labels": {},\n  "name": "",\n  "release": {\n    "message": "",\n    "name": "",\n    "releaseTime": "",\n    "releaseUser": {\n      "email": "",\n      "imageUrl": ""\n    },\n    "type": "",\n    "version": {\n      "config": {\n        "appAssociation": "",\n        "cleanUrls": false,\n        "headers": [\n          {\n            "glob": "",\n            "headers": {},\n            "regex": ""\n          }\n        ],\n        "i18n": {\n          "root": ""\n        },\n        "redirects": [\n          {\n            "glob": "",\n            "location": "",\n            "regex": "",\n            "statusCode": 0\n          }\n        ],\n        "rewrites": [\n          {\n            "dynamicLinks": false,\n            "function": "",\n            "functionRegion": "",\n            "glob": "",\n            "path": "",\n            "regex": "",\n            "run": {\n              "region": "",\n              "serviceId": ""\n            }\n          }\n        ],\n        "trailingSlashBehavior": ""\n      },\n      "createTime": "",\n      "createUser": {},\n      "deleteTime": "",\n      "deleteUser": {},\n      "fileCount": "",\n      "finalizeTime": "",\n      "finalizeUser": {},\n      "labels": {},\n      "name": "",\n      "status": "",\n      "versionBytes": ""\n    }\n  },\n  "retainedReleaseCount": 0,\n  "ttl": "",\n  "updateTime": "",\n  "url": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/channels")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

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

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

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

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

req.write(JSON.stringify({
  createTime: '',
  expireTime: '',
  labels: {},
  name: '',
  release: {
    message: '',
    name: '',
    releaseTime: '',
    releaseUser: {email: '', imageUrl: ''},
    type: '',
    version: {
      config: {
        appAssociation: '',
        cleanUrls: false,
        headers: [{glob: '', headers: {}, regex: ''}],
        i18n: {root: ''},
        redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
        rewrites: [
          {
            dynamicLinks: false,
            function: '',
            functionRegion: '',
            glob: '',
            path: '',
            regex: '',
            run: {region: '', serviceId: ''}
          }
        ],
        trailingSlashBehavior: ''
      },
      createTime: '',
      createUser: {},
      deleteTime: '',
      deleteUser: {},
      fileCount: '',
      finalizeTime: '',
      finalizeUser: {},
      labels: {},
      name: '',
      status: '',
      versionBytes: ''
    }
  },
  retainedReleaseCount: 0,
  ttl: '',
  updateTime: '',
  url: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/channels',
  headers: {'content-type': 'application/json'},
  body: {
    createTime: '',
    expireTime: '',
    labels: {},
    name: '',
    release: {
      message: '',
      name: '',
      releaseTime: '',
      releaseUser: {email: '', imageUrl: ''},
      type: '',
      version: {
        config: {
          appAssociation: '',
          cleanUrls: false,
          headers: [{glob: '', headers: {}, regex: ''}],
          i18n: {root: ''},
          redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
          rewrites: [
            {
              dynamicLinks: false,
              function: '',
              functionRegion: '',
              glob: '',
              path: '',
              regex: '',
              run: {region: '', serviceId: ''}
            }
          ],
          trailingSlashBehavior: ''
        },
        createTime: '',
        createUser: {},
        deleteTime: '',
        deleteUser: {},
        fileCount: '',
        finalizeTime: '',
        finalizeUser: {},
        labels: {},
        name: '',
        status: '',
        versionBytes: ''
      }
    },
    retainedReleaseCount: 0,
    ttl: '',
    updateTime: '',
    url: ''
  },
  json: true
};

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

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

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

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

req.type('json');
req.send({
  createTime: '',
  expireTime: '',
  labels: {},
  name: '',
  release: {
    message: '',
    name: '',
    releaseTime: '',
    releaseUser: {
      email: '',
      imageUrl: ''
    },
    type: '',
    version: {
      config: {
        appAssociation: '',
        cleanUrls: false,
        headers: [
          {
            glob: '',
            headers: {},
            regex: ''
          }
        ],
        i18n: {
          root: ''
        },
        redirects: [
          {
            glob: '',
            location: '',
            regex: '',
            statusCode: 0
          }
        ],
        rewrites: [
          {
            dynamicLinks: false,
            function: '',
            functionRegion: '',
            glob: '',
            path: '',
            regex: '',
            run: {
              region: '',
              serviceId: ''
            }
          }
        ],
        trailingSlashBehavior: ''
      },
      createTime: '',
      createUser: {},
      deleteTime: '',
      deleteUser: {},
      fileCount: '',
      finalizeTime: '',
      finalizeUser: {},
      labels: {},
      name: '',
      status: '',
      versionBytes: ''
    }
  },
  retainedReleaseCount: 0,
  ttl: '',
  updateTime: '',
  url: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/channels',
  headers: {'content-type': 'application/json'},
  data: {
    createTime: '',
    expireTime: '',
    labels: {},
    name: '',
    release: {
      message: '',
      name: '',
      releaseTime: '',
      releaseUser: {email: '', imageUrl: ''},
      type: '',
      version: {
        config: {
          appAssociation: '',
          cleanUrls: false,
          headers: [{glob: '', headers: {}, regex: ''}],
          i18n: {root: ''},
          redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
          rewrites: [
            {
              dynamicLinks: false,
              function: '',
              functionRegion: '',
              glob: '',
              path: '',
              regex: '',
              run: {region: '', serviceId: ''}
            }
          ],
          trailingSlashBehavior: ''
        },
        createTime: '',
        createUser: {},
        deleteTime: '',
        deleteUser: {},
        fileCount: '',
        finalizeTime: '',
        finalizeUser: {},
        labels: {},
        name: '',
        status: '',
        versionBytes: ''
      }
    },
    retainedReleaseCount: 0,
    ttl: '',
    updateTime: '',
    url: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:parent/channels';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"createTime":"","expireTime":"","labels":{},"name":"","release":{"message":"","name":"","releaseTime":"","releaseUser":{"email":"","imageUrl":""},"type":"","version":{"config":{"appAssociation":"","cleanUrls":false,"headers":[{"glob":"","headers":{},"regex":""}],"i18n":{"root":""},"redirects":[{"glob":"","location":"","regex":"","statusCode":0}],"rewrites":[{"dynamicLinks":false,"function":"","functionRegion":"","glob":"","path":"","regex":"","run":{"region":"","serviceId":""}}],"trailingSlashBehavior":""},"createTime":"","createUser":{},"deleteTime":"","deleteUser":{},"fileCount":"","finalizeTime":"","finalizeUser":{},"labels":{},"name":"","status":"","versionBytes":""}},"retainedReleaseCount":0,"ttl":"","updateTime":"","url":""}'
};

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

NSDictionary *headers = @{ @"content-type": @"application/json" };
NSDictionary *parameters = @{ @"createTime": @"",
                              @"expireTime": @"",
                              @"labels": @{  },
                              @"name": @"",
                              @"release": @{ @"message": @"", @"name": @"", @"releaseTime": @"", @"releaseUser": @{ @"email": @"", @"imageUrl": @"" }, @"type": @"", @"version": @{ @"config": @{ @"appAssociation": @"", @"cleanUrls": @NO, @"headers": @[ @{ @"glob": @"", @"headers": @{  }, @"regex": @"" } ], @"i18n": @{ @"root": @"" }, @"redirects": @[ @{ @"glob": @"", @"location": @"", @"regex": @"", @"statusCode": @0 } ], @"rewrites": @[ @{ @"dynamicLinks": @NO, @"function": @"", @"functionRegion": @"", @"glob": @"", @"path": @"", @"regex": @"", @"run": @{ @"region": @"", @"serviceId": @"" } } ], @"trailingSlashBehavior": @"" }, @"createTime": @"", @"createUser": @{  }, @"deleteTime": @"", @"deleteUser": @{  }, @"fileCount": @"", @"finalizeTime": @"", @"finalizeUser": @{  }, @"labels": @{  }, @"name": @"", @"status": @"", @"versionBytes": @"" } },
                              @"retainedReleaseCount": @0,
                              @"ttl": @"",
                              @"updateTime": @"",
                              @"url": @"" };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:parent/channels" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:parent/channels",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'createTime' => '',
    'expireTime' => '',
    'labels' => [
        
    ],
    'name' => '',
    'release' => [
        'message' => '',
        'name' => '',
        'releaseTime' => '',
        'releaseUser' => [
                'email' => '',
                'imageUrl' => ''
        ],
        'type' => '',
        'version' => [
                'config' => [
                                'appAssociation' => '',
                                'cleanUrls' => null,
                                'headers' => [
                                                                [
                                                                                                                                'glob' => '',
                                                                                                                                'headers' => [
                                                                                                                                                                                                                                                                
                                                                                                                                ],
                                                                                                                                'regex' => ''
                                                                ]
                                ],
                                'i18n' => [
                                                                'root' => ''
                                ],
                                'redirects' => [
                                                                [
                                                                                                                                'glob' => '',
                                                                                                                                'location' => '',
                                                                                                                                'regex' => '',
                                                                                                                                'statusCode' => 0
                                                                ]
                                ],
                                'rewrites' => [
                                                                [
                                                                                                                                'dynamicLinks' => null,
                                                                                                                                'function' => '',
                                                                                                                                'functionRegion' => '',
                                                                                                                                'glob' => '',
                                                                                                                                'path' => '',
                                                                                                                                'regex' => '',
                                                                                                                                'run' => [
                                                                                                                                                                                                                                                                'region' => '',
                                                                                                                                                                                                                                                                'serviceId' => ''
                                                                                                                                ]
                                                                ]
                                ],
                                'trailingSlashBehavior' => ''
                ],
                'createTime' => '',
                'createUser' => [
                                
                ],
                'deleteTime' => '',
                'deleteUser' => [
                                
                ],
                'fileCount' => '',
                'finalizeTime' => '',
                'finalizeUser' => [
                                
                ],
                'labels' => [
                                
                ],
                'name' => '',
                'status' => '',
                'versionBytes' => ''
        ]
    ],
    'retainedReleaseCount' => 0,
    'ttl' => '',
    'updateTime' => '',
    'url' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1beta1/:parent/channels', [
  'body' => '{
  "createTime": "",
  "expireTime": "",
  "labels": {},
  "name": "",
  "release": {
    "message": "",
    "name": "",
    "releaseTime": "",
    "releaseUser": {
      "email": "",
      "imageUrl": ""
    },
    "type": "",
    "version": {
      "config": {
        "appAssociation": "",
        "cleanUrls": false,
        "headers": [
          {
            "glob": "",
            "headers": {},
            "regex": ""
          }
        ],
        "i18n": {
          "root": ""
        },
        "redirects": [
          {
            "glob": "",
            "location": "",
            "regex": "",
            "statusCode": 0
          }
        ],
        "rewrites": [
          {
            "dynamicLinks": false,
            "function": "",
            "functionRegion": "",
            "glob": "",
            "path": "",
            "regex": "",
            "run": {
              "region": "",
              "serviceId": ""
            }
          }
        ],
        "trailingSlashBehavior": ""
      },
      "createTime": "",
      "createUser": {},
      "deleteTime": "",
      "deleteUser": {},
      "fileCount": "",
      "finalizeTime": "",
      "finalizeUser": {},
      "labels": {},
      "name": "",
      "status": "",
      "versionBytes": ""
    }
  },
  "retainedReleaseCount": 0,
  "ttl": "",
  "updateTime": "",
  "url": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'createTime' => '',
  'expireTime' => '',
  'labels' => [
    
  ],
  'name' => '',
  'release' => [
    'message' => '',
    'name' => '',
    'releaseTime' => '',
    'releaseUser' => [
        'email' => '',
        'imageUrl' => ''
    ],
    'type' => '',
    'version' => [
        'config' => [
                'appAssociation' => '',
                'cleanUrls' => null,
                'headers' => [
                                [
                                                                'glob' => '',
                                                                'headers' => [
                                                                                                                                
                                                                ],
                                                                'regex' => ''
                                ]
                ],
                'i18n' => [
                                'root' => ''
                ],
                'redirects' => [
                                [
                                                                'glob' => '',
                                                                'location' => '',
                                                                'regex' => '',
                                                                'statusCode' => 0
                                ]
                ],
                'rewrites' => [
                                [
                                                                'dynamicLinks' => null,
                                                                'function' => '',
                                                                'functionRegion' => '',
                                                                'glob' => '',
                                                                'path' => '',
                                                                'regex' => '',
                                                                'run' => [
                                                                                                                                'region' => '',
                                                                                                                                'serviceId' => ''
                                                                ]
                                ]
                ],
                'trailingSlashBehavior' => ''
        ],
        'createTime' => '',
        'createUser' => [
                
        ],
        'deleteTime' => '',
        'deleteUser' => [
                
        ],
        'fileCount' => '',
        'finalizeTime' => '',
        'finalizeUser' => [
                
        ],
        'labels' => [
                
        ],
        'name' => '',
        'status' => '',
        'versionBytes' => ''
    ]
  ],
  'retainedReleaseCount' => 0,
  'ttl' => '',
  'updateTime' => '',
  'url' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'createTime' => '',
  'expireTime' => '',
  'labels' => [
    
  ],
  'name' => '',
  'release' => [
    'message' => '',
    'name' => '',
    'releaseTime' => '',
    'releaseUser' => [
        'email' => '',
        'imageUrl' => ''
    ],
    'type' => '',
    'version' => [
        'config' => [
                'appAssociation' => '',
                'cleanUrls' => null,
                'headers' => [
                                [
                                                                'glob' => '',
                                                                'headers' => [
                                                                                                                                
                                                                ],
                                                                'regex' => ''
                                ]
                ],
                'i18n' => [
                                'root' => ''
                ],
                'redirects' => [
                                [
                                                                'glob' => '',
                                                                'location' => '',
                                                                'regex' => '',
                                                                'statusCode' => 0
                                ]
                ],
                'rewrites' => [
                                [
                                                                'dynamicLinks' => null,
                                                                'function' => '',
                                                                'functionRegion' => '',
                                                                'glob' => '',
                                                                'path' => '',
                                                                'regex' => '',
                                                                'run' => [
                                                                                                                                'region' => '',
                                                                                                                                'serviceId' => ''
                                                                ]
                                ]
                ],
                'trailingSlashBehavior' => ''
        ],
        'createTime' => '',
        'createUser' => [
                
        ],
        'deleteTime' => '',
        'deleteUser' => [
                
        ],
        'fileCount' => '',
        'finalizeTime' => '',
        'finalizeUser' => [
                
        ],
        'labels' => [
                
        ],
        'name' => '',
        'status' => '',
        'versionBytes' => ''
    ]
  ],
  'retainedReleaseCount' => 0,
  'ttl' => '',
  'updateTime' => '',
  'url' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:parent/channels');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:parent/channels' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "createTime": "",
  "expireTime": "",
  "labels": {},
  "name": "",
  "release": {
    "message": "",
    "name": "",
    "releaseTime": "",
    "releaseUser": {
      "email": "",
      "imageUrl": ""
    },
    "type": "",
    "version": {
      "config": {
        "appAssociation": "",
        "cleanUrls": false,
        "headers": [
          {
            "glob": "",
            "headers": {},
            "regex": ""
          }
        ],
        "i18n": {
          "root": ""
        },
        "redirects": [
          {
            "glob": "",
            "location": "",
            "regex": "",
            "statusCode": 0
          }
        ],
        "rewrites": [
          {
            "dynamicLinks": false,
            "function": "",
            "functionRegion": "",
            "glob": "",
            "path": "",
            "regex": "",
            "run": {
              "region": "",
              "serviceId": ""
            }
          }
        ],
        "trailingSlashBehavior": ""
      },
      "createTime": "",
      "createUser": {},
      "deleteTime": "",
      "deleteUser": {},
      "fileCount": "",
      "finalizeTime": "",
      "finalizeUser": {},
      "labels": {},
      "name": "",
      "status": "",
      "versionBytes": ""
    }
  },
  "retainedReleaseCount": 0,
  "ttl": "",
  "updateTime": "",
  "url": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent/channels' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "createTime": "",
  "expireTime": "",
  "labels": {},
  "name": "",
  "release": {
    "message": "",
    "name": "",
    "releaseTime": "",
    "releaseUser": {
      "email": "",
      "imageUrl": ""
    },
    "type": "",
    "version": {
      "config": {
        "appAssociation": "",
        "cleanUrls": false,
        "headers": [
          {
            "glob": "",
            "headers": {},
            "regex": ""
          }
        ],
        "i18n": {
          "root": ""
        },
        "redirects": [
          {
            "glob": "",
            "location": "",
            "regex": "",
            "statusCode": 0
          }
        ],
        "rewrites": [
          {
            "dynamicLinks": false,
            "function": "",
            "functionRegion": "",
            "glob": "",
            "path": "",
            "regex": "",
            "run": {
              "region": "",
              "serviceId": ""
            }
          }
        ],
        "trailingSlashBehavior": ""
      },
      "createTime": "",
      "createUser": {},
      "deleteTime": "",
      "deleteUser": {},
      "fileCount": "",
      "finalizeTime": "",
      "finalizeUser": {},
      "labels": {},
      "name": "",
      "status": "",
      "versionBytes": ""
    }
  },
  "retainedReleaseCount": 0,
  "ttl": "",
  "updateTime": "",
  "url": ""
}'
import http.client

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

payload = "{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}"

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

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

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

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

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

payload = {
    "createTime": "",
    "expireTime": "",
    "labels": {},
    "name": "",
    "release": {
        "message": "",
        "name": "",
        "releaseTime": "",
        "releaseUser": {
            "email": "",
            "imageUrl": ""
        },
        "type": "",
        "version": {
            "config": {
                "appAssociation": "",
                "cleanUrls": False,
                "headers": [
                    {
                        "glob": "",
                        "headers": {},
                        "regex": ""
                    }
                ],
                "i18n": { "root": "" },
                "redirects": [
                    {
                        "glob": "",
                        "location": "",
                        "regex": "",
                        "statusCode": 0
                    }
                ],
                "rewrites": [
                    {
                        "dynamicLinks": False,
                        "function": "",
                        "functionRegion": "",
                        "glob": "",
                        "path": "",
                        "regex": "",
                        "run": {
                            "region": "",
                            "serviceId": ""
                        }
                    }
                ],
                "trailingSlashBehavior": ""
            },
            "createTime": "",
            "createUser": {},
            "deleteTime": "",
            "deleteUser": {},
            "fileCount": "",
            "finalizeTime": "",
            "finalizeUser": {},
            "labels": {},
            "name": "",
            "status": "",
            "versionBytes": ""
        }
    },
    "retainedReleaseCount": 0,
    "ttl": "",
    "updateTime": "",
    "url": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}"

encode <- "json"

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

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

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

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}"

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

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

response = conn.post('/baseUrl/v1beta1/:parent/channels') do |req|
  req.body = "{\n  \"createTime\": \"\",\n  \"expireTime\": \"\",\n  \"labels\": {},\n  \"name\": \"\",\n  \"release\": {\n    \"message\": \"\",\n    \"name\": \"\",\n    \"releaseTime\": \"\",\n    \"releaseUser\": {\n      \"email\": \"\",\n      \"imageUrl\": \"\"\n    },\n    \"type\": \"\",\n    \"version\": {\n      \"config\": {\n        \"appAssociation\": \"\",\n        \"cleanUrls\": false,\n        \"headers\": [\n          {\n            \"glob\": \"\",\n            \"headers\": {},\n            \"regex\": \"\"\n          }\n        ],\n        \"i18n\": {\n          \"root\": \"\"\n        },\n        \"redirects\": [\n          {\n            \"glob\": \"\",\n            \"location\": \"\",\n            \"regex\": \"\",\n            \"statusCode\": 0\n          }\n        ],\n        \"rewrites\": [\n          {\n            \"dynamicLinks\": false,\n            \"function\": \"\",\n            \"functionRegion\": \"\",\n            \"glob\": \"\",\n            \"path\": \"\",\n            \"regex\": \"\",\n            \"run\": {\n              \"region\": \"\",\n              \"serviceId\": \"\"\n            }\n          }\n        ],\n        \"trailingSlashBehavior\": \"\"\n      },\n      \"createTime\": \"\",\n      \"createUser\": {},\n      \"deleteTime\": \"\",\n      \"deleteUser\": {},\n      \"fileCount\": \"\",\n      \"finalizeTime\": \"\",\n      \"finalizeUser\": {},\n      \"labels\": {},\n      \"name\": \"\",\n      \"status\": \"\",\n      \"versionBytes\": \"\"\n    }\n  },\n  \"retainedReleaseCount\": 0,\n  \"ttl\": \"\",\n  \"updateTime\": \"\",\n  \"url\": \"\"\n}"
end

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

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

    let payload = json!({
        "createTime": "",
        "expireTime": "",
        "labels": json!({}),
        "name": "",
        "release": json!({
            "message": "",
            "name": "",
            "releaseTime": "",
            "releaseUser": json!({
                "email": "",
                "imageUrl": ""
            }),
            "type": "",
            "version": json!({
                "config": json!({
                    "appAssociation": "",
                    "cleanUrls": false,
                    "headers": (
                        json!({
                            "glob": "",
                            "headers": json!({}),
                            "regex": ""
                        })
                    ),
                    "i18n": json!({"root": ""}),
                    "redirects": (
                        json!({
                            "glob": "",
                            "location": "",
                            "regex": "",
                            "statusCode": 0
                        })
                    ),
                    "rewrites": (
                        json!({
                            "dynamicLinks": false,
                            "function": "",
                            "functionRegion": "",
                            "glob": "",
                            "path": "",
                            "regex": "",
                            "run": json!({
                                "region": "",
                                "serviceId": ""
                            })
                        })
                    ),
                    "trailingSlashBehavior": ""
                }),
                "createTime": "",
                "createUser": json!({}),
                "deleteTime": "",
                "deleteUser": json!({}),
                "fileCount": "",
                "finalizeTime": "",
                "finalizeUser": json!({}),
                "labels": json!({}),
                "name": "",
                "status": "",
                "versionBytes": ""
            })
        }),
        "retainedReleaseCount": 0,
        "ttl": "",
        "updateTime": "",
        "url": ""
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1beta1/:parent/channels \
  --header 'content-type: application/json' \
  --data '{
  "createTime": "",
  "expireTime": "",
  "labels": {},
  "name": "",
  "release": {
    "message": "",
    "name": "",
    "releaseTime": "",
    "releaseUser": {
      "email": "",
      "imageUrl": ""
    },
    "type": "",
    "version": {
      "config": {
        "appAssociation": "",
        "cleanUrls": false,
        "headers": [
          {
            "glob": "",
            "headers": {},
            "regex": ""
          }
        ],
        "i18n": {
          "root": ""
        },
        "redirects": [
          {
            "glob": "",
            "location": "",
            "regex": "",
            "statusCode": 0
          }
        ],
        "rewrites": [
          {
            "dynamicLinks": false,
            "function": "",
            "functionRegion": "",
            "glob": "",
            "path": "",
            "regex": "",
            "run": {
              "region": "",
              "serviceId": ""
            }
          }
        ],
        "trailingSlashBehavior": ""
      },
      "createTime": "",
      "createUser": {},
      "deleteTime": "",
      "deleteUser": {},
      "fileCount": "",
      "finalizeTime": "",
      "finalizeUser": {},
      "labels": {},
      "name": "",
      "status": "",
      "versionBytes": ""
    }
  },
  "retainedReleaseCount": 0,
  "ttl": "",
  "updateTime": "",
  "url": ""
}'
echo '{
  "createTime": "",
  "expireTime": "",
  "labels": {},
  "name": "",
  "release": {
    "message": "",
    "name": "",
    "releaseTime": "",
    "releaseUser": {
      "email": "",
      "imageUrl": ""
    },
    "type": "",
    "version": {
      "config": {
        "appAssociation": "",
        "cleanUrls": false,
        "headers": [
          {
            "glob": "",
            "headers": {},
            "regex": ""
          }
        ],
        "i18n": {
          "root": ""
        },
        "redirects": [
          {
            "glob": "",
            "location": "",
            "regex": "",
            "statusCode": 0
          }
        ],
        "rewrites": [
          {
            "dynamicLinks": false,
            "function": "",
            "functionRegion": "",
            "glob": "",
            "path": "",
            "regex": "",
            "run": {
              "region": "",
              "serviceId": ""
            }
          }
        ],
        "trailingSlashBehavior": ""
      },
      "createTime": "",
      "createUser": {},
      "deleteTime": "",
      "deleteUser": {},
      "fileCount": "",
      "finalizeTime": "",
      "finalizeUser": {},
      "labels": {},
      "name": "",
      "status": "",
      "versionBytes": ""
    }
  },
  "retainedReleaseCount": 0,
  "ttl": "",
  "updateTime": "",
  "url": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:parent/channels \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "createTime": "",\n  "expireTime": "",\n  "labels": {},\n  "name": "",\n  "release": {\n    "message": "",\n    "name": "",\n    "releaseTime": "",\n    "releaseUser": {\n      "email": "",\n      "imageUrl": ""\n    },\n    "type": "",\n    "version": {\n      "config": {\n        "appAssociation": "",\n        "cleanUrls": false,\n        "headers": [\n          {\n            "glob": "",\n            "headers": {},\n            "regex": ""\n          }\n        ],\n        "i18n": {\n          "root": ""\n        },\n        "redirects": [\n          {\n            "glob": "",\n            "location": "",\n            "regex": "",\n            "statusCode": 0\n          }\n        ],\n        "rewrites": [\n          {\n            "dynamicLinks": false,\n            "function": "",\n            "functionRegion": "",\n            "glob": "",\n            "path": "",\n            "regex": "",\n            "run": {\n              "region": "",\n              "serviceId": ""\n            }\n          }\n        ],\n        "trailingSlashBehavior": ""\n      },\n      "createTime": "",\n      "createUser": {},\n      "deleteTime": "",\n      "deleteUser": {},\n      "fileCount": "",\n      "finalizeTime": "",\n      "finalizeUser": {},\n      "labels": {},\n      "name": "",\n      "status": "",\n      "versionBytes": ""\n    }\n  },\n  "retainedReleaseCount": 0,\n  "ttl": "",\n  "updateTime": "",\n  "url": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/channels
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "createTime": "",
  "expireTime": "",
  "labels": [],
  "name": "",
  "release": [
    "message": "",
    "name": "",
    "releaseTime": "",
    "releaseUser": [
      "email": "",
      "imageUrl": ""
    ],
    "type": "",
    "version": [
      "config": [
        "appAssociation": "",
        "cleanUrls": false,
        "headers": [
          [
            "glob": "",
            "headers": [],
            "regex": ""
          ]
        ],
        "i18n": ["root": ""],
        "redirects": [
          [
            "glob": "",
            "location": "",
            "regex": "",
            "statusCode": 0
          ]
        ],
        "rewrites": [
          [
            "dynamicLinks": false,
            "function": "",
            "functionRegion": "",
            "glob": "",
            "path": "",
            "regex": "",
            "run": [
              "region": "",
              "serviceId": ""
            ]
          ]
        ],
        "trailingSlashBehavior": ""
      ],
      "createTime": "",
      "createUser": [],
      "deleteTime": "",
      "deleteUser": [],
      "fileCount": "",
      "finalizeTime": "",
      "finalizeUser": [],
      "labels": [],
      "name": "",
      "status": "",
      "versionBytes": ""
    ]
  ],
  "retainedReleaseCount": 0,
  "ttl": "",
  "updateTime": "",
  "url": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/channels")! 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 firebasehosting.sites.channels.list
{{baseUrl}}/v1beta1/:parent/channels
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

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

func main() {

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

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

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

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

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

}
GET /baseUrl/v1beta1/:parent/channels HTTP/1.1
Host: example.com

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

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

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

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

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

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

xhr.open('GET', '{{baseUrl}}/v1beta1/:parent/channels');

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

curl_close($curl);

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

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

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

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

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

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

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

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

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

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

response = requests.get(url)

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

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

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

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

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

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/channels")! 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 firebasehosting.sites.domains.create
{{baseUrl}}/v1beta1/:parent/domains
QUERY PARAMS

parent
BODY json

{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:parent/domains" {:content-type :json
                                                                    :form-params {:domainName ""
                                                                                  :domainRedirect {:domainName ""
                                                                                                   :type ""}
                                                                                  :provisioning {:certChallengeDiscoveredTxt []
                                                                                                 :certChallengeDns {:domainName ""
                                                                                                                    :token ""}
                                                                                                 :certChallengeHttp {:path ""
                                                                                                                     :token ""}
                                                                                                 :certStatus ""
                                                                                                 :discoveredIps []
                                                                                                 :dnsFetchTime ""
                                                                                                 :dnsStatus ""
                                                                                                 :expectedIps []}
                                                                                  :site ""
                                                                                  :status ""
                                                                                  :updateTime ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/domains"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1beta1/:parent/domains"),
    Content = new StringContent("{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/:parent/domains");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}")

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

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

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

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

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

}
POST /baseUrl/v1beta1/:parent/domains HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 458

{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:parent/domains")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:parent/domains"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\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  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/domains")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:parent/domains")
  .header("content-type", "application/json")
  .body("{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  domainName: '',
  domainRedirect: {
    domainName: '',
    type: ''
  },
  provisioning: {
    certChallengeDiscoveredTxt: [],
    certChallengeDns: {
      domainName: '',
      token: ''
    },
    certChallengeHttp: {
      path: '',
      token: ''
    },
    certStatus: '',
    discoveredIps: [],
    dnsFetchTime: '',
    dnsStatus: '',
    expectedIps: []
  },
  site: '',
  status: '',
  updateTime: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/domains',
  headers: {'content-type': 'application/json'},
  data: {
    domainName: '',
    domainRedirect: {domainName: '', type: ''},
    provisioning: {
      certChallengeDiscoveredTxt: [],
      certChallengeDns: {domainName: '', token: ''},
      certChallengeHttp: {path: '', token: ''},
      certStatus: '',
      discoveredIps: [],
      dnsFetchTime: '',
      dnsStatus: '',
      expectedIps: []
    },
    site: '',
    status: '',
    updateTime: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent/domains';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"domainName":"","domainRedirect":{"domainName":"","type":""},"provisioning":{"certChallengeDiscoveredTxt":[],"certChallengeDns":{"domainName":"","token":""},"certChallengeHttp":{"path":"","token":""},"certStatus":"","discoveredIps":[],"dnsFetchTime":"","dnsStatus":"","expectedIps":[]},"site":"","status":"","updateTime":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:parent/domains',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "domainName": "",\n  "domainRedirect": {\n    "domainName": "",\n    "type": ""\n  },\n  "provisioning": {\n    "certChallengeDiscoveredTxt": [],\n    "certChallengeDns": {\n      "domainName": "",\n      "token": ""\n    },\n    "certChallengeHttp": {\n      "path": "",\n      "token": ""\n    },\n    "certStatus": "",\n    "discoveredIps": [],\n    "dnsFetchTime": "",\n    "dnsStatus": "",\n    "expectedIps": []\n  },\n  "site": "",\n  "status": "",\n  "updateTime": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/domains")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/:parent/domains',
  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({
  domainName: '',
  domainRedirect: {domainName: '', type: ''},
  provisioning: {
    certChallengeDiscoveredTxt: [],
    certChallengeDns: {domainName: '', token: ''},
    certChallengeHttp: {path: '', token: ''},
    certStatus: '',
    discoveredIps: [],
    dnsFetchTime: '',
    dnsStatus: '',
    expectedIps: []
  },
  site: '',
  status: '',
  updateTime: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/domains',
  headers: {'content-type': 'application/json'},
  body: {
    domainName: '',
    domainRedirect: {domainName: '', type: ''},
    provisioning: {
      certChallengeDiscoveredTxt: [],
      certChallengeDns: {domainName: '', token: ''},
      certChallengeHttp: {path: '', token: ''},
      certStatus: '',
      discoveredIps: [],
      dnsFetchTime: '',
      dnsStatus: '',
      expectedIps: []
    },
    site: '',
    status: '',
    updateTime: ''
  },
  json: true
};

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

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

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

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

req.type('json');
req.send({
  domainName: '',
  domainRedirect: {
    domainName: '',
    type: ''
  },
  provisioning: {
    certChallengeDiscoveredTxt: [],
    certChallengeDns: {
      domainName: '',
      token: ''
    },
    certChallengeHttp: {
      path: '',
      token: ''
    },
    certStatus: '',
    discoveredIps: [],
    dnsFetchTime: '',
    dnsStatus: '',
    expectedIps: []
  },
  site: '',
  status: '',
  updateTime: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/domains',
  headers: {'content-type': 'application/json'},
  data: {
    domainName: '',
    domainRedirect: {domainName: '', type: ''},
    provisioning: {
      certChallengeDiscoveredTxt: [],
      certChallengeDns: {domainName: '', token: ''},
      certChallengeHttp: {path: '', token: ''},
      certStatus: '',
      discoveredIps: [],
      dnsFetchTime: '',
      dnsStatus: '',
      expectedIps: []
    },
    site: '',
    status: '',
    updateTime: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:parent/domains';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"domainName":"","domainRedirect":{"domainName":"","type":""},"provisioning":{"certChallengeDiscoveredTxt":[],"certChallengeDns":{"domainName":"","token":""},"certChallengeHttp":{"path":"","token":""},"certStatus":"","discoveredIps":[],"dnsFetchTime":"","dnsStatus":"","expectedIps":[]},"site":"","status":"","updateTime":""}'
};

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 = @{ @"domainName": @"",
                              @"domainRedirect": @{ @"domainName": @"", @"type": @"" },
                              @"provisioning": @{ @"certChallengeDiscoveredTxt": @[  ], @"certChallengeDns": @{ @"domainName": @"", @"token": @"" }, @"certChallengeHttp": @{ @"path": @"", @"token": @"" }, @"certStatus": @"", @"discoveredIps": @[  ], @"dnsFetchTime": @"", @"dnsStatus": @"", @"expectedIps": @[  ] },
                              @"site": @"",
                              @"status": @"",
                              @"updateTime": @"" };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:parent/domains" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:parent/domains",
  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([
    'domainName' => '',
    'domainRedirect' => [
        'domainName' => '',
        'type' => ''
    ],
    'provisioning' => [
        'certChallengeDiscoveredTxt' => [
                
        ],
        'certChallengeDns' => [
                'domainName' => '',
                'token' => ''
        ],
        'certChallengeHttp' => [
                'path' => '',
                'token' => ''
        ],
        'certStatus' => '',
        'discoveredIps' => [
                
        ],
        'dnsFetchTime' => '',
        'dnsStatus' => '',
        'expectedIps' => [
                
        ]
    ],
    'site' => '',
    'status' => '',
    'updateTime' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1beta1/:parent/domains', [
  'body' => '{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'domainName' => '',
  'domainRedirect' => [
    'domainName' => '',
    'type' => ''
  ],
  'provisioning' => [
    'certChallengeDiscoveredTxt' => [
        
    ],
    'certChallengeDns' => [
        'domainName' => '',
        'token' => ''
    ],
    'certChallengeHttp' => [
        'path' => '',
        'token' => ''
    ],
    'certStatus' => '',
    'discoveredIps' => [
        
    ],
    'dnsFetchTime' => '',
    'dnsStatus' => '',
    'expectedIps' => [
        
    ]
  ],
  'site' => '',
  'status' => '',
  'updateTime' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'domainName' => '',
  'domainRedirect' => [
    'domainName' => '',
    'type' => ''
  ],
  'provisioning' => [
    'certChallengeDiscoveredTxt' => [
        
    ],
    'certChallengeDns' => [
        'domainName' => '',
        'token' => ''
    ],
    'certChallengeHttp' => [
        'path' => '',
        'token' => ''
    ],
    'certStatus' => '',
    'discoveredIps' => [
        
    ],
    'dnsFetchTime' => '',
    'dnsStatus' => '',
    'expectedIps' => [
        
    ]
  ],
  'site' => '',
  'status' => '',
  'updateTime' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:parent/domains');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:parent/domains' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent/domains' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}'
import http.client

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

payload = "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}"

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

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

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

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

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

payload = {
    "domainName": "",
    "domainRedirect": {
        "domainName": "",
        "type": ""
    },
    "provisioning": {
        "certChallengeDiscoveredTxt": [],
        "certChallengeDns": {
            "domainName": "",
            "token": ""
        },
        "certChallengeHttp": {
            "path": "",
            "token": ""
        },
        "certStatus": "",
        "discoveredIps": [],
        "dnsFetchTime": "",
        "dnsStatus": "",
        "expectedIps": []
    },
    "site": "",
    "status": "",
    "updateTime": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}"

encode <- "json"

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

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

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

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  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}"

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

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

response = conn.post('/baseUrl/v1beta1/:parent/domains') do |req|
  req.body = "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}"
end

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

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

    let payload = json!({
        "domainName": "",
        "domainRedirect": json!({
            "domainName": "",
            "type": ""
        }),
        "provisioning": json!({
            "certChallengeDiscoveredTxt": (),
            "certChallengeDns": json!({
                "domainName": "",
                "token": ""
            }),
            "certChallengeHttp": json!({
                "path": "",
                "token": ""
            }),
            "certStatus": "",
            "discoveredIps": (),
            "dnsFetchTime": "",
            "dnsStatus": "",
            "expectedIps": ()
        }),
        "site": "",
        "status": "",
        "updateTime": ""
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1beta1/:parent/domains \
  --header 'content-type: application/json' \
  --data '{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}'
echo '{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:parent/domains \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "domainName": "",\n  "domainRedirect": {\n    "domainName": "",\n    "type": ""\n  },\n  "provisioning": {\n    "certChallengeDiscoveredTxt": [],\n    "certChallengeDns": {\n      "domainName": "",\n      "token": ""\n    },\n    "certChallengeHttp": {\n      "path": "",\n      "token": ""\n    },\n    "certStatus": "",\n    "discoveredIps": [],\n    "dnsFetchTime": "",\n    "dnsStatus": "",\n    "expectedIps": []\n  },\n  "site": "",\n  "status": "",\n  "updateTime": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/domains
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "domainName": "",
  "domainRedirect": [
    "domainName": "",
    "type": ""
  ],
  "provisioning": [
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": [
      "domainName": "",
      "token": ""
    ],
    "certChallengeHttp": [
      "path": "",
      "token": ""
    ],
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  ],
  "site": "",
  "status": "",
  "updateTime": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/domains")! 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 firebasehosting.sites.domains.list
{{baseUrl}}/v1beta1/:parent/domains
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

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

func main() {

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

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

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

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

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

}
GET /baseUrl/v1beta1/:parent/domains HTTP/1.1
Host: example.com

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

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

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

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

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

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

xhr.open('GET', '{{baseUrl}}/v1beta1/:parent/domains');

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

curl_close($curl);

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

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

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

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

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

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

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

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

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

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

response = requests.get(url)

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

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

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

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

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

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

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

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

dataTask.resume()
PUT firebasehosting.sites.domains.update
{{baseUrl}}/v1beta1/:name
QUERY PARAMS

name
BODY json

{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}");

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

(client/put "{{baseUrl}}/v1beta1/:name" {:content-type :json
                                                         :form-params {:domainName ""
                                                                       :domainRedirect {:domainName ""
                                                                                        :type ""}
                                                                       :provisioning {:certChallengeDiscoveredTxt []
                                                                                      :certChallengeDns {:domainName ""
                                                                                                         :token ""}
                                                                                      :certChallengeHttp {:path ""
                                                                                                          :token ""}
                                                                                      :certStatus ""
                                                                                      :discoveredIps []
                                                                                      :dnsFetchTime ""
                                                                                      :dnsStatus ""
                                                                                      :expectedIps []}
                                                                       :site ""
                                                                       :status ""
                                                                       :updateTime ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}"

response = HTTP::Client.put url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Put,
    RequestUri = new Uri("{{baseUrl}}/v1beta1/:name"),
    Content = new StringContent("{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/:name");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}")

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

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

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

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

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

}
PUT /baseUrl/v1beta1/:name HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 458

{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/v1beta1/:name")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\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  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/v1beta1/:name")
  .header("content-type", "application/json")
  .body("{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  domainName: '',
  domainRedirect: {
    domainName: '',
    type: ''
  },
  provisioning: {
    certChallengeDiscoveredTxt: [],
    certChallengeDns: {
      domainName: '',
      token: ''
    },
    certChallengeHttp: {
      path: '',
      token: ''
    },
    certStatus: '',
    discoveredIps: [],
    dnsFetchTime: '',
    dnsStatus: '',
    expectedIps: []
  },
  site: '',
  status: '',
  updateTime: ''
});

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v1beta1/:name',
  headers: {'content-type': 'application/json'},
  data: {
    domainName: '',
    domainRedirect: {domainName: '', type: ''},
    provisioning: {
      certChallengeDiscoveredTxt: [],
      certChallengeDns: {domainName: '', token: ''},
      certChallengeHttp: {path: '', token: ''},
      certStatus: '',
      discoveredIps: [],
      dnsFetchTime: '',
      dnsStatus: '',
      expectedIps: []
    },
    site: '',
    status: '',
    updateTime: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"domainName":"","domainRedirect":{"domainName":"","type":""},"provisioning":{"certChallengeDiscoveredTxt":[],"certChallengeDns":{"domainName":"","token":""},"certChallengeHttp":{"path":"","token":""},"certStatus":"","discoveredIps":[],"dnsFetchTime":"","dnsStatus":"","expectedIps":[]},"site":"","status":"","updateTime":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:name',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "domainName": "",\n  "domainRedirect": {\n    "domainName": "",\n    "type": ""\n  },\n  "provisioning": {\n    "certChallengeDiscoveredTxt": [],\n    "certChallengeDns": {\n      "domainName": "",\n      "token": ""\n    },\n    "certChallengeHttp": {\n      "path": "",\n      "token": ""\n    },\n    "certStatus": "",\n    "discoveredIps": [],\n    "dnsFetchTime": "",\n    "dnsStatus": "",\n    "expectedIps": []\n  },\n  "site": "",\n  "status": "",\n  "updateTime": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name")
  .put(body)
  .addHeader("content-type", "application/json")
  .build()

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

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

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

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

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

req.write(JSON.stringify({
  domainName: '',
  domainRedirect: {domainName: '', type: ''},
  provisioning: {
    certChallengeDiscoveredTxt: [],
    certChallengeDns: {domainName: '', token: ''},
    certChallengeHttp: {path: '', token: ''},
    certStatus: '',
    discoveredIps: [],
    dnsFetchTime: '',
    dnsStatus: '',
    expectedIps: []
  },
  site: '',
  status: '',
  updateTime: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v1beta1/:name',
  headers: {'content-type': 'application/json'},
  body: {
    domainName: '',
    domainRedirect: {domainName: '', type: ''},
    provisioning: {
      certChallengeDiscoveredTxt: [],
      certChallengeDns: {domainName: '', token: ''},
      certChallengeHttp: {path: '', token: ''},
      certStatus: '',
      discoveredIps: [],
      dnsFetchTime: '',
      dnsStatus: '',
      expectedIps: []
    },
    site: '',
    status: '',
    updateTime: ''
  },
  json: true
};

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

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

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

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

req.type('json');
req.send({
  domainName: '',
  domainRedirect: {
    domainName: '',
    type: ''
  },
  provisioning: {
    certChallengeDiscoveredTxt: [],
    certChallengeDns: {
      domainName: '',
      token: ''
    },
    certChallengeHttp: {
      path: '',
      token: ''
    },
    certStatus: '',
    discoveredIps: [],
    dnsFetchTime: '',
    dnsStatus: '',
    expectedIps: []
  },
  site: '',
  status: '',
  updateTime: ''
});

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/v1beta1/:name',
  headers: {'content-type': 'application/json'},
  data: {
    domainName: '',
    domainRedirect: {domainName: '', type: ''},
    provisioning: {
      certChallengeDiscoveredTxt: [],
      certChallengeDns: {domainName: '', token: ''},
      certChallengeHttp: {path: '', token: ''},
      certStatus: '',
      discoveredIps: [],
      dnsFetchTime: '',
      dnsStatus: '',
      expectedIps: []
    },
    site: '',
    status: '',
    updateTime: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:name';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"domainName":"","domainRedirect":{"domainName":"","type":""},"provisioning":{"certChallengeDiscoveredTxt":[],"certChallengeDns":{"domainName":"","token":""},"certChallengeHttp":{"path":"","token":""},"certStatus":"","discoveredIps":[],"dnsFetchTime":"","dnsStatus":"","expectedIps":[]},"site":"","status":"","updateTime":""}'
};

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 = @{ @"domainName": @"",
                              @"domainRedirect": @{ @"domainName": @"", @"type": @"" },
                              @"provisioning": @{ @"certChallengeDiscoveredTxt": @[  ], @"certChallengeDns": @{ @"domainName": @"", @"token": @"" }, @"certChallengeHttp": @{ @"path": @"", @"token": @"" }, @"certStatus": @"", @"discoveredIps": @[  ], @"dnsFetchTime": @"", @"dnsStatus": @"", @"expectedIps": @[  ] },
                              @"site": @"",
                              @"status": @"",
                              @"updateTime": @"" };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:name" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PUT",
  CURLOPT_POSTFIELDS => json_encode([
    'domainName' => '',
    'domainRedirect' => [
        'domainName' => '',
        'type' => ''
    ],
    'provisioning' => [
        'certChallengeDiscoveredTxt' => [
                
        ],
        'certChallengeDns' => [
                'domainName' => '',
                'token' => ''
        ],
        'certChallengeHttp' => [
                'path' => '',
                'token' => ''
        ],
        'certStatus' => '',
        'discoveredIps' => [
                
        ],
        'dnsFetchTime' => '',
        'dnsStatus' => '',
        'expectedIps' => [
                
        ]
    ],
    'site' => '',
    'status' => '',
    'updateTime' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('PUT', '{{baseUrl}}/v1beta1/:name', [
  'body' => '{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'domainName' => '',
  'domainRedirect' => [
    'domainName' => '',
    'type' => ''
  ],
  'provisioning' => [
    'certChallengeDiscoveredTxt' => [
        
    ],
    'certChallengeDns' => [
        'domainName' => '',
        'token' => ''
    ],
    'certChallengeHttp' => [
        'path' => '',
        'token' => ''
    ],
    'certStatus' => '',
    'discoveredIps' => [
        
    ],
    'dnsFetchTime' => '',
    'dnsStatus' => '',
    'expectedIps' => [
        
    ]
  ],
  'site' => '',
  'status' => '',
  'updateTime' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'domainName' => '',
  'domainRedirect' => [
    'domainName' => '',
    'type' => ''
  ],
  'provisioning' => [
    'certChallengeDiscoveredTxt' => [
        
    ],
    'certChallengeDns' => [
        'domainName' => '',
        'token' => ''
    ],
    'certChallengeHttp' => [
        'path' => '',
        'token' => ''
    ],
    'certStatus' => '',
    'discoveredIps' => [
        
    ],
    'dnsFetchTime' => '',
    'dnsStatus' => '',
    'expectedIps' => [
        
    ]
  ],
  'site' => '',
  'status' => '',
  'updateTime' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:name');
$request->setRequestMethod('PUT');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:name' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}'
import http.client

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

payload = "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}"

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

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

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

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

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

payload = {
    "domainName": "",
    "domainRedirect": {
        "domainName": "",
        "type": ""
    },
    "provisioning": {
        "certChallengeDiscoveredTxt": [],
        "certChallengeDns": {
            "domainName": "",
            "token": ""
        },
        "certChallengeHttp": {
            "path": "",
            "token": ""
        },
        "certStatus": "",
        "discoveredIps": [],
        "dnsFetchTime": "",
        "dnsStatus": "",
        "expectedIps": []
    },
    "site": "",
    "status": "",
    "updateTime": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}"

encode <- "json"

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

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

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

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

request = Net::HTTP::Put.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}"

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

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

response = conn.put('/baseUrl/v1beta1/:name') do |req|
  req.body = "{\n  \"domainName\": \"\",\n  \"domainRedirect\": {\n    \"domainName\": \"\",\n    \"type\": \"\"\n  },\n  \"provisioning\": {\n    \"certChallengeDiscoveredTxt\": [],\n    \"certChallengeDns\": {\n      \"domainName\": \"\",\n      \"token\": \"\"\n    },\n    \"certChallengeHttp\": {\n      \"path\": \"\",\n      \"token\": \"\"\n    },\n    \"certStatus\": \"\",\n    \"discoveredIps\": [],\n    \"dnsFetchTime\": \"\",\n    \"dnsStatus\": \"\",\n    \"expectedIps\": []\n  },\n  \"site\": \"\",\n  \"status\": \"\",\n  \"updateTime\": \"\"\n}"
end

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

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

    let payload = json!({
        "domainName": "",
        "domainRedirect": json!({
            "domainName": "",
            "type": ""
        }),
        "provisioning": json!({
            "certChallengeDiscoveredTxt": (),
            "certChallengeDns": json!({
                "domainName": "",
                "token": ""
            }),
            "certChallengeHttp": json!({
                "path": "",
                "token": ""
            }),
            "certStatus": "",
            "discoveredIps": (),
            "dnsFetchTime": "",
            "dnsStatus": "",
            "expectedIps": ()
        }),
        "site": "",
        "status": "",
        "updateTime": ""
    });

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

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

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

    dbg!(results);
}
curl --request PUT \
  --url {{baseUrl}}/v1beta1/:name \
  --header 'content-type: application/json' \
  --data '{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}'
echo '{
  "domainName": "",
  "domainRedirect": {
    "domainName": "",
    "type": ""
  },
  "provisioning": {
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": {
      "domainName": "",
      "token": ""
    },
    "certChallengeHttp": {
      "path": "",
      "token": ""
    },
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  },
  "site": "",
  "status": "",
  "updateTime": ""
}' |  \
  http PUT {{baseUrl}}/v1beta1/:name \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "domainName": "",\n  "domainRedirect": {\n    "domainName": "",\n    "type": ""\n  },\n  "provisioning": {\n    "certChallengeDiscoveredTxt": [],\n    "certChallengeDns": {\n      "domainName": "",\n      "token": ""\n    },\n    "certChallengeHttp": {\n      "path": "",\n      "token": ""\n    },\n    "certStatus": "",\n    "discoveredIps": [],\n    "dnsFetchTime": "",\n    "dnsStatus": "",\n    "expectedIps": []\n  },\n  "site": "",\n  "status": "",\n  "updateTime": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "domainName": "",
  "domainRedirect": [
    "domainName": "",
    "type": ""
  ],
  "provisioning": [
    "certChallengeDiscoveredTxt": [],
    "certChallengeDns": [
      "domainName": "",
      "token": ""
    ],
    "certChallengeHttp": [
      "path": "",
      "token": ""
    ],
    "certStatus": "",
    "discoveredIps": [],
    "dnsFetchTime": "",
    "dnsStatus": "",
    "expectedIps": []
  ],
  "site": "",
  "status": "",
  "updateTime": ""
] as [String : Any]

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

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

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

dataTask.resume()
POST firebasehosting.sites.releases.create
{{baseUrl}}/v1beta1/:parent/releases
QUERY PARAMS

parent
BODY json

{
  "message": "",
  "name": "",
  "releaseTime": "",
  "releaseUser": {
    "email": "",
    "imageUrl": ""
  },
  "type": "",
  "version": {
    "config": {
      "appAssociation": "",
      "cleanUrls": false,
      "headers": [
        {
          "glob": "",
          "headers": {},
          "regex": ""
        }
      ],
      "i18n": {
        "root": ""
      },
      "redirects": [
        {
          "glob": "",
          "location": "",
          "regex": "",
          "statusCode": 0
        }
      ],
      "rewrites": [
        {
          "dynamicLinks": false,
          "function": "",
          "functionRegion": "",
          "glob": "",
          "path": "",
          "regex": "",
          "run": {
            "region": "",
            "serviceId": ""
          }
        }
      ],
      "trailingSlashBehavior": ""
    },
    "createTime": "",
    "createUser": {},
    "deleteTime": "",
    "deleteUser": {},
    "fileCount": "",
    "finalizeTime": "",
    "finalizeUser": {},
    "labels": {},
    "name": "",
    "status": "",
    "versionBytes": ""
  }
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\n  }\n}");

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

(client/post "{{baseUrl}}/v1beta1/:parent/releases" {:content-type :json
                                                                     :form-params {:message ""
                                                                                   :name ""
                                                                                   :releaseTime ""
                                                                                   :releaseUser {:email ""
                                                                                                 :imageUrl ""}
                                                                                   :type ""
                                                                                   :version {:config {:appAssociation ""
                                                                                                      :cleanUrls false
                                                                                                      :headers [{:glob ""
                                                                                                                 :headers {}
                                                                                                                 :regex ""}]
                                                                                                      :i18n {:root ""}
                                                                                                      :redirects [{:glob ""
                                                                                                                   :location ""
                                                                                                                   :regex ""
                                                                                                                   :statusCode 0}]
                                                                                                      :rewrites [{:dynamicLinks false
                                                                                                                  :function ""
                                                                                                                  :functionRegion ""
                                                                                                                  :glob ""
                                                                                                                  :path ""
                                                                                                                  :regex ""
                                                                                                                  :run {:region ""
                                                                                                                        :serviceId ""}}]
                                                                                                      :trailingSlashBehavior ""}
                                                                                             :createTime ""
                                                                                             :createUser {}
                                                                                             :deleteTime ""
                                                                                             :deleteUser {}
                                                                                             :fileCount ""
                                                                                             :finalizeTime ""
                                                                                             :finalizeUser {}
                                                                                             :labels {}
                                                                                             :name ""
                                                                                             :status ""
                                                                                             :versionBytes ""}}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/releases"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\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}}/v1beta1/:parent/releases"),
    Content = new StringContent("{\n  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\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}}/v1beta1/:parent/releases");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\n  }\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\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/v1beta1/:parent/releases HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1091

{
  "message": "",
  "name": "",
  "releaseTime": "",
  "releaseUser": {
    "email": "",
    "imageUrl": ""
  },
  "type": "",
  "version": {
    "config": {
      "appAssociation": "",
      "cleanUrls": false,
      "headers": [
        {
          "glob": "",
          "headers": {},
          "regex": ""
        }
      ],
      "i18n": {
        "root": ""
      },
      "redirects": [
        {
          "glob": "",
          "location": "",
          "regex": "",
          "statusCode": 0
        }
      ],
      "rewrites": [
        {
          "dynamicLinks": false,
          "function": "",
          "functionRegion": "",
          "glob": "",
          "path": "",
          "regex": "",
          "run": {
            "region": "",
            "serviceId": ""
          }
        }
      ],
      "trailingSlashBehavior": ""
    },
    "createTime": "",
    "createUser": {},
    "deleteTime": "",
    "deleteUser": {},
    "fileCount": "",
    "finalizeTime": "",
    "finalizeUser": {},
    "labels": {},
    "name": "",
    "status": "",
    "versionBytes": ""
  }
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:parent/releases")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\n  }\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:parent/releases"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\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  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\n  }\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/releases")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:parent/releases")
  .header("content-type", "application/json")
  .body("{\n  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\n  }\n}")
  .asString();
const data = JSON.stringify({
  message: '',
  name: '',
  releaseTime: '',
  releaseUser: {
    email: '',
    imageUrl: ''
  },
  type: '',
  version: {
    config: {
      appAssociation: '',
      cleanUrls: false,
      headers: [
        {
          glob: '',
          headers: {},
          regex: ''
        }
      ],
      i18n: {
        root: ''
      },
      redirects: [
        {
          glob: '',
          location: '',
          regex: '',
          statusCode: 0
        }
      ],
      rewrites: [
        {
          dynamicLinks: false,
          function: '',
          functionRegion: '',
          glob: '',
          path: '',
          regex: '',
          run: {
            region: '',
            serviceId: ''
          }
        }
      ],
      trailingSlashBehavior: ''
    },
    createTime: '',
    createUser: {},
    deleteTime: '',
    deleteUser: {},
    fileCount: '',
    finalizeTime: '',
    finalizeUser: {},
    labels: {},
    name: '',
    status: '',
    versionBytes: ''
  }
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/releases',
  headers: {'content-type': 'application/json'},
  data: {
    message: '',
    name: '',
    releaseTime: '',
    releaseUser: {email: '', imageUrl: ''},
    type: '',
    version: {
      config: {
        appAssociation: '',
        cleanUrls: false,
        headers: [{glob: '', headers: {}, regex: ''}],
        i18n: {root: ''},
        redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
        rewrites: [
          {
            dynamicLinks: false,
            function: '',
            functionRegion: '',
            glob: '',
            path: '',
            regex: '',
            run: {region: '', serviceId: ''}
          }
        ],
        trailingSlashBehavior: ''
      },
      createTime: '',
      createUser: {},
      deleteTime: '',
      deleteUser: {},
      fileCount: '',
      finalizeTime: '',
      finalizeUser: {},
      labels: {},
      name: '',
      status: '',
      versionBytes: ''
    }
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent/releases';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"message":"","name":"","releaseTime":"","releaseUser":{"email":"","imageUrl":""},"type":"","version":{"config":{"appAssociation":"","cleanUrls":false,"headers":[{"glob":"","headers":{},"regex":""}],"i18n":{"root":""},"redirects":[{"glob":"","location":"","regex":"","statusCode":0}],"rewrites":[{"dynamicLinks":false,"function":"","functionRegion":"","glob":"","path":"","regex":"","run":{"region":"","serviceId":""}}],"trailingSlashBehavior":""},"createTime":"","createUser":{},"deleteTime":"","deleteUser":{},"fileCount":"","finalizeTime":"","finalizeUser":{},"labels":{},"name":"","status":"","versionBytes":""}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:parent/releases',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "message": "",\n  "name": "",\n  "releaseTime": "",\n  "releaseUser": {\n    "email": "",\n    "imageUrl": ""\n  },\n  "type": "",\n  "version": {\n    "config": {\n      "appAssociation": "",\n      "cleanUrls": false,\n      "headers": [\n        {\n          "glob": "",\n          "headers": {},\n          "regex": ""\n        }\n      ],\n      "i18n": {\n        "root": ""\n      },\n      "redirects": [\n        {\n          "glob": "",\n          "location": "",\n          "regex": "",\n          "statusCode": 0\n        }\n      ],\n      "rewrites": [\n        {\n          "dynamicLinks": false,\n          "function": "",\n          "functionRegion": "",\n          "glob": "",\n          "path": "",\n          "regex": "",\n          "run": {\n            "region": "",\n            "serviceId": ""\n          }\n        }\n      ],\n      "trailingSlashBehavior": ""\n    },\n    "createTime": "",\n    "createUser": {},\n    "deleteTime": "",\n    "deleteUser": {},\n    "fileCount": "",\n    "finalizeTime": "",\n    "finalizeUser": {},\n    "labels": {},\n    "name": "",\n    "status": "",\n    "versionBytes": ""\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  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\n  }\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/releases")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/:parent/releases',
  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({
  message: '',
  name: '',
  releaseTime: '',
  releaseUser: {email: '', imageUrl: ''},
  type: '',
  version: {
    config: {
      appAssociation: '',
      cleanUrls: false,
      headers: [{glob: '', headers: {}, regex: ''}],
      i18n: {root: ''},
      redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
      rewrites: [
        {
          dynamicLinks: false,
          function: '',
          functionRegion: '',
          glob: '',
          path: '',
          regex: '',
          run: {region: '', serviceId: ''}
        }
      ],
      trailingSlashBehavior: ''
    },
    createTime: '',
    createUser: {},
    deleteTime: '',
    deleteUser: {},
    fileCount: '',
    finalizeTime: '',
    finalizeUser: {},
    labels: {},
    name: '',
    status: '',
    versionBytes: ''
  }
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/releases',
  headers: {'content-type': 'application/json'},
  body: {
    message: '',
    name: '',
    releaseTime: '',
    releaseUser: {email: '', imageUrl: ''},
    type: '',
    version: {
      config: {
        appAssociation: '',
        cleanUrls: false,
        headers: [{glob: '', headers: {}, regex: ''}],
        i18n: {root: ''},
        redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
        rewrites: [
          {
            dynamicLinks: false,
            function: '',
            functionRegion: '',
            glob: '',
            path: '',
            regex: '',
            run: {region: '', serviceId: ''}
          }
        ],
        trailingSlashBehavior: ''
      },
      createTime: '',
      createUser: {},
      deleteTime: '',
      deleteUser: {},
      fileCount: '',
      finalizeTime: '',
      finalizeUser: {},
      labels: {},
      name: '',
      status: '',
      versionBytes: ''
    }
  },
  json: true
};

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

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

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

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

req.type('json');
req.send({
  message: '',
  name: '',
  releaseTime: '',
  releaseUser: {
    email: '',
    imageUrl: ''
  },
  type: '',
  version: {
    config: {
      appAssociation: '',
      cleanUrls: false,
      headers: [
        {
          glob: '',
          headers: {},
          regex: ''
        }
      ],
      i18n: {
        root: ''
      },
      redirects: [
        {
          glob: '',
          location: '',
          regex: '',
          statusCode: 0
        }
      ],
      rewrites: [
        {
          dynamicLinks: false,
          function: '',
          functionRegion: '',
          glob: '',
          path: '',
          regex: '',
          run: {
            region: '',
            serviceId: ''
          }
        }
      ],
      trailingSlashBehavior: ''
    },
    createTime: '',
    createUser: {},
    deleteTime: '',
    deleteUser: {},
    fileCount: '',
    finalizeTime: '',
    finalizeUser: {},
    labels: {},
    name: '',
    status: '',
    versionBytes: ''
  }
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/releases',
  headers: {'content-type': 'application/json'},
  data: {
    message: '',
    name: '',
    releaseTime: '',
    releaseUser: {email: '', imageUrl: ''},
    type: '',
    version: {
      config: {
        appAssociation: '',
        cleanUrls: false,
        headers: [{glob: '', headers: {}, regex: ''}],
        i18n: {root: ''},
        redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
        rewrites: [
          {
            dynamicLinks: false,
            function: '',
            functionRegion: '',
            glob: '',
            path: '',
            regex: '',
            run: {region: '', serviceId: ''}
          }
        ],
        trailingSlashBehavior: ''
      },
      createTime: '',
      createUser: {},
      deleteTime: '',
      deleteUser: {},
      fileCount: '',
      finalizeTime: '',
      finalizeUser: {},
      labels: {},
      name: '',
      status: '',
      versionBytes: ''
    }
  }
};

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

const url = '{{baseUrl}}/v1beta1/:parent/releases';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"message":"","name":"","releaseTime":"","releaseUser":{"email":"","imageUrl":""},"type":"","version":{"config":{"appAssociation":"","cleanUrls":false,"headers":[{"glob":"","headers":{},"regex":""}],"i18n":{"root":""},"redirects":[{"glob":"","location":"","regex":"","statusCode":0}],"rewrites":[{"dynamicLinks":false,"function":"","functionRegion":"","glob":"","path":"","regex":"","run":{"region":"","serviceId":""}}],"trailingSlashBehavior":""},"createTime":"","createUser":{},"deleteTime":"","deleteUser":{},"fileCount":"","finalizeTime":"","finalizeUser":{},"labels":{},"name":"","status":"","versionBytes":""}}'
};

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 = @{ @"message": @"",
                              @"name": @"",
                              @"releaseTime": @"",
                              @"releaseUser": @{ @"email": @"", @"imageUrl": @"" },
                              @"type": @"",
                              @"version": @{ @"config": @{ @"appAssociation": @"", @"cleanUrls": @NO, @"headers": @[ @{ @"glob": @"", @"headers": @{  }, @"regex": @"" } ], @"i18n": @{ @"root": @"" }, @"redirects": @[ @{ @"glob": @"", @"location": @"", @"regex": @"", @"statusCode": @0 } ], @"rewrites": @[ @{ @"dynamicLinks": @NO, @"function": @"", @"functionRegion": @"", @"glob": @"", @"path": @"", @"regex": @"", @"run": @{ @"region": @"", @"serviceId": @"" } } ], @"trailingSlashBehavior": @"" }, @"createTime": @"", @"createUser": @{  }, @"deleteTime": @"", @"deleteUser": @{  }, @"fileCount": @"", @"finalizeTime": @"", @"finalizeUser": @{  }, @"labels": @{  }, @"name": @"", @"status": @"", @"versionBytes": @"" } };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:parent/releases" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\n  }\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:parent/releases",
  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([
    'message' => '',
    'name' => '',
    'releaseTime' => '',
    'releaseUser' => [
        'email' => '',
        'imageUrl' => ''
    ],
    'type' => '',
    'version' => [
        'config' => [
                'appAssociation' => '',
                'cleanUrls' => null,
                'headers' => [
                                [
                                                                'glob' => '',
                                                                'headers' => [
                                                                                                                                
                                                                ],
                                                                'regex' => ''
                                ]
                ],
                'i18n' => [
                                'root' => ''
                ],
                'redirects' => [
                                [
                                                                'glob' => '',
                                                                'location' => '',
                                                                'regex' => '',
                                                                'statusCode' => 0
                                ]
                ],
                'rewrites' => [
                                [
                                                                'dynamicLinks' => null,
                                                                'function' => '',
                                                                'functionRegion' => '',
                                                                'glob' => '',
                                                                'path' => '',
                                                                'regex' => '',
                                                                'run' => [
                                                                                                                                'region' => '',
                                                                                                                                'serviceId' => ''
                                                                ]
                                ]
                ],
                'trailingSlashBehavior' => ''
        ],
        'createTime' => '',
        'createUser' => [
                
        ],
        'deleteTime' => '',
        'deleteUser' => [
                
        ],
        'fileCount' => '',
        'finalizeTime' => '',
        'finalizeUser' => [
                
        ],
        'labels' => [
                
        ],
        'name' => '',
        'status' => '',
        'versionBytes' => ''
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1beta1/:parent/releases', [
  'body' => '{
  "message": "",
  "name": "",
  "releaseTime": "",
  "releaseUser": {
    "email": "",
    "imageUrl": ""
  },
  "type": "",
  "version": {
    "config": {
      "appAssociation": "",
      "cleanUrls": false,
      "headers": [
        {
          "glob": "",
          "headers": {},
          "regex": ""
        }
      ],
      "i18n": {
        "root": ""
      },
      "redirects": [
        {
          "glob": "",
          "location": "",
          "regex": "",
          "statusCode": 0
        }
      ],
      "rewrites": [
        {
          "dynamicLinks": false,
          "function": "",
          "functionRegion": "",
          "glob": "",
          "path": "",
          "regex": "",
          "run": {
            "region": "",
            "serviceId": ""
          }
        }
      ],
      "trailingSlashBehavior": ""
    },
    "createTime": "",
    "createUser": {},
    "deleteTime": "",
    "deleteUser": {},
    "fileCount": "",
    "finalizeTime": "",
    "finalizeUser": {},
    "labels": {},
    "name": "",
    "status": "",
    "versionBytes": ""
  }
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'message' => '',
  'name' => '',
  'releaseTime' => '',
  'releaseUser' => [
    'email' => '',
    'imageUrl' => ''
  ],
  'type' => '',
  'version' => [
    'config' => [
        'appAssociation' => '',
        'cleanUrls' => null,
        'headers' => [
                [
                                'glob' => '',
                                'headers' => [
                                                                
                                ],
                                'regex' => ''
                ]
        ],
        'i18n' => [
                'root' => ''
        ],
        'redirects' => [
                [
                                'glob' => '',
                                'location' => '',
                                'regex' => '',
                                'statusCode' => 0
                ]
        ],
        'rewrites' => [
                [
                                'dynamicLinks' => null,
                                'function' => '',
                                'functionRegion' => '',
                                'glob' => '',
                                'path' => '',
                                'regex' => '',
                                'run' => [
                                                                'region' => '',
                                                                'serviceId' => ''
                                ]
                ]
        ],
        'trailingSlashBehavior' => ''
    ],
    'createTime' => '',
    'createUser' => [
        
    ],
    'deleteTime' => '',
    'deleteUser' => [
        
    ],
    'fileCount' => '',
    'finalizeTime' => '',
    'finalizeUser' => [
        
    ],
    'labels' => [
        
    ],
    'name' => '',
    'status' => '',
    'versionBytes' => ''
  ]
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'message' => '',
  'name' => '',
  'releaseTime' => '',
  'releaseUser' => [
    'email' => '',
    'imageUrl' => ''
  ],
  'type' => '',
  'version' => [
    'config' => [
        'appAssociation' => '',
        'cleanUrls' => null,
        'headers' => [
                [
                                'glob' => '',
                                'headers' => [
                                                                
                                ],
                                'regex' => ''
                ]
        ],
        'i18n' => [
                'root' => ''
        ],
        'redirects' => [
                [
                                'glob' => '',
                                'location' => '',
                                'regex' => '',
                                'statusCode' => 0
                ]
        ],
        'rewrites' => [
                [
                                'dynamicLinks' => null,
                                'function' => '',
                                'functionRegion' => '',
                                'glob' => '',
                                'path' => '',
                                'regex' => '',
                                'run' => [
                                                                'region' => '',
                                                                'serviceId' => ''
                                ]
                ]
        ],
        'trailingSlashBehavior' => ''
    ],
    'createTime' => '',
    'createUser' => [
        
    ],
    'deleteTime' => '',
    'deleteUser' => [
        
    ],
    'fileCount' => '',
    'finalizeTime' => '',
    'finalizeUser' => [
        
    ],
    'labels' => [
        
    ],
    'name' => '',
    'status' => '',
    'versionBytes' => ''
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:parent/releases');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:parent/releases' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "message": "",
  "name": "",
  "releaseTime": "",
  "releaseUser": {
    "email": "",
    "imageUrl": ""
  },
  "type": "",
  "version": {
    "config": {
      "appAssociation": "",
      "cleanUrls": false,
      "headers": [
        {
          "glob": "",
          "headers": {},
          "regex": ""
        }
      ],
      "i18n": {
        "root": ""
      },
      "redirects": [
        {
          "glob": "",
          "location": "",
          "regex": "",
          "statusCode": 0
        }
      ],
      "rewrites": [
        {
          "dynamicLinks": false,
          "function": "",
          "functionRegion": "",
          "glob": "",
          "path": "",
          "regex": "",
          "run": {
            "region": "",
            "serviceId": ""
          }
        }
      ],
      "trailingSlashBehavior": ""
    },
    "createTime": "",
    "createUser": {},
    "deleteTime": "",
    "deleteUser": {},
    "fileCount": "",
    "finalizeTime": "",
    "finalizeUser": {},
    "labels": {},
    "name": "",
    "status": "",
    "versionBytes": ""
  }
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent/releases' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "message": "",
  "name": "",
  "releaseTime": "",
  "releaseUser": {
    "email": "",
    "imageUrl": ""
  },
  "type": "",
  "version": {
    "config": {
      "appAssociation": "",
      "cleanUrls": false,
      "headers": [
        {
          "glob": "",
          "headers": {},
          "regex": ""
        }
      ],
      "i18n": {
        "root": ""
      },
      "redirects": [
        {
          "glob": "",
          "location": "",
          "regex": "",
          "statusCode": 0
        }
      ],
      "rewrites": [
        {
          "dynamicLinks": false,
          "function": "",
          "functionRegion": "",
          "glob": "",
          "path": "",
          "regex": "",
          "run": {
            "region": "",
            "serviceId": ""
          }
        }
      ],
      "trailingSlashBehavior": ""
    },
    "createTime": "",
    "createUser": {},
    "deleteTime": "",
    "deleteUser": {},
    "fileCount": "",
    "finalizeTime": "",
    "finalizeUser": {},
    "labels": {},
    "name": "",
    "status": "",
    "versionBytes": ""
  }
}'
import http.client

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

payload = "{\n  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\n  }\n}"

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

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

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

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

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

payload = {
    "message": "",
    "name": "",
    "releaseTime": "",
    "releaseUser": {
        "email": "",
        "imageUrl": ""
    },
    "type": "",
    "version": {
        "config": {
            "appAssociation": "",
            "cleanUrls": False,
            "headers": [
                {
                    "glob": "",
                    "headers": {},
                    "regex": ""
                }
            ],
            "i18n": { "root": "" },
            "redirects": [
                {
                    "glob": "",
                    "location": "",
                    "regex": "",
                    "statusCode": 0
                }
            ],
            "rewrites": [
                {
                    "dynamicLinks": False,
                    "function": "",
                    "functionRegion": "",
                    "glob": "",
                    "path": "",
                    "regex": "",
                    "run": {
                        "region": "",
                        "serviceId": ""
                    }
                }
            ],
            "trailingSlashBehavior": ""
        },
        "createTime": "",
        "createUser": {},
        "deleteTime": "",
        "deleteUser": {},
        "fileCount": "",
        "finalizeTime": "",
        "finalizeUser": {},
        "labels": {},
        "name": "",
        "status": "",
        "versionBytes": ""
    }
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\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}}/v1beta1/:parent/releases")

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  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\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/v1beta1/:parent/releases') do |req|
  req.body = "{\n  \"message\": \"\",\n  \"name\": \"\",\n  \"releaseTime\": \"\",\n  \"releaseUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"type\": \"\",\n  \"version\": {\n    \"config\": {\n      \"appAssociation\": \"\",\n      \"cleanUrls\": false,\n      \"headers\": [\n        {\n          \"glob\": \"\",\n          \"headers\": {},\n          \"regex\": \"\"\n        }\n      ],\n      \"i18n\": {\n        \"root\": \"\"\n      },\n      \"redirects\": [\n        {\n          \"glob\": \"\",\n          \"location\": \"\",\n          \"regex\": \"\",\n          \"statusCode\": 0\n        }\n      ],\n      \"rewrites\": [\n        {\n          \"dynamicLinks\": false,\n          \"function\": \"\",\n          \"functionRegion\": \"\",\n          \"glob\": \"\",\n          \"path\": \"\",\n          \"regex\": \"\",\n          \"run\": {\n            \"region\": \"\",\n            \"serviceId\": \"\"\n          }\n        }\n      ],\n      \"trailingSlashBehavior\": \"\"\n    },\n    \"createTime\": \"\",\n    \"createUser\": {},\n    \"deleteTime\": \"\",\n    \"deleteUser\": {},\n    \"fileCount\": \"\",\n    \"finalizeTime\": \"\",\n    \"finalizeUser\": {},\n    \"labels\": {},\n    \"name\": \"\",\n    \"status\": \"\",\n    \"versionBytes\": \"\"\n  }\n}"
end

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

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

    let payload = json!({
        "message": "",
        "name": "",
        "releaseTime": "",
        "releaseUser": json!({
            "email": "",
            "imageUrl": ""
        }),
        "type": "",
        "version": json!({
            "config": json!({
                "appAssociation": "",
                "cleanUrls": false,
                "headers": (
                    json!({
                        "glob": "",
                        "headers": json!({}),
                        "regex": ""
                    })
                ),
                "i18n": json!({"root": ""}),
                "redirects": (
                    json!({
                        "glob": "",
                        "location": "",
                        "regex": "",
                        "statusCode": 0
                    })
                ),
                "rewrites": (
                    json!({
                        "dynamicLinks": false,
                        "function": "",
                        "functionRegion": "",
                        "glob": "",
                        "path": "",
                        "regex": "",
                        "run": json!({
                            "region": "",
                            "serviceId": ""
                        })
                    })
                ),
                "trailingSlashBehavior": ""
            }),
            "createTime": "",
            "createUser": json!({}),
            "deleteTime": "",
            "deleteUser": json!({}),
            "fileCount": "",
            "finalizeTime": "",
            "finalizeUser": json!({}),
            "labels": json!({}),
            "name": "",
            "status": "",
            "versionBytes": ""
        })
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1beta1/:parent/releases \
  --header 'content-type: application/json' \
  --data '{
  "message": "",
  "name": "",
  "releaseTime": "",
  "releaseUser": {
    "email": "",
    "imageUrl": ""
  },
  "type": "",
  "version": {
    "config": {
      "appAssociation": "",
      "cleanUrls": false,
      "headers": [
        {
          "glob": "",
          "headers": {},
          "regex": ""
        }
      ],
      "i18n": {
        "root": ""
      },
      "redirects": [
        {
          "glob": "",
          "location": "",
          "regex": "",
          "statusCode": 0
        }
      ],
      "rewrites": [
        {
          "dynamicLinks": false,
          "function": "",
          "functionRegion": "",
          "glob": "",
          "path": "",
          "regex": "",
          "run": {
            "region": "",
            "serviceId": ""
          }
        }
      ],
      "trailingSlashBehavior": ""
    },
    "createTime": "",
    "createUser": {},
    "deleteTime": "",
    "deleteUser": {},
    "fileCount": "",
    "finalizeTime": "",
    "finalizeUser": {},
    "labels": {},
    "name": "",
    "status": "",
    "versionBytes": ""
  }
}'
echo '{
  "message": "",
  "name": "",
  "releaseTime": "",
  "releaseUser": {
    "email": "",
    "imageUrl": ""
  },
  "type": "",
  "version": {
    "config": {
      "appAssociation": "",
      "cleanUrls": false,
      "headers": [
        {
          "glob": "",
          "headers": {},
          "regex": ""
        }
      ],
      "i18n": {
        "root": ""
      },
      "redirects": [
        {
          "glob": "",
          "location": "",
          "regex": "",
          "statusCode": 0
        }
      ],
      "rewrites": [
        {
          "dynamicLinks": false,
          "function": "",
          "functionRegion": "",
          "glob": "",
          "path": "",
          "regex": "",
          "run": {
            "region": "",
            "serviceId": ""
          }
        }
      ],
      "trailingSlashBehavior": ""
    },
    "createTime": "",
    "createUser": {},
    "deleteTime": "",
    "deleteUser": {},
    "fileCount": "",
    "finalizeTime": "",
    "finalizeUser": {},
    "labels": {},
    "name": "",
    "status": "",
    "versionBytes": ""
  }
}' |  \
  http POST {{baseUrl}}/v1beta1/:parent/releases \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "message": "",\n  "name": "",\n  "releaseTime": "",\n  "releaseUser": {\n    "email": "",\n    "imageUrl": ""\n  },\n  "type": "",\n  "version": {\n    "config": {\n      "appAssociation": "",\n      "cleanUrls": false,\n      "headers": [\n        {\n          "glob": "",\n          "headers": {},\n          "regex": ""\n        }\n      ],\n      "i18n": {\n        "root": ""\n      },\n      "redirects": [\n        {\n          "glob": "",\n          "location": "",\n          "regex": "",\n          "statusCode": 0\n        }\n      ],\n      "rewrites": [\n        {\n          "dynamicLinks": false,\n          "function": "",\n          "functionRegion": "",\n          "glob": "",\n          "path": "",\n          "regex": "",\n          "run": {\n            "region": "",\n            "serviceId": ""\n          }\n        }\n      ],\n      "trailingSlashBehavior": ""\n    },\n    "createTime": "",\n    "createUser": {},\n    "deleteTime": "",\n    "deleteUser": {},\n    "fileCount": "",\n    "finalizeTime": "",\n    "finalizeUser": {},\n    "labels": {},\n    "name": "",\n    "status": "",\n    "versionBytes": ""\n  }\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/releases
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "message": "",
  "name": "",
  "releaseTime": "",
  "releaseUser": [
    "email": "",
    "imageUrl": ""
  ],
  "type": "",
  "version": [
    "config": [
      "appAssociation": "",
      "cleanUrls": false,
      "headers": [
        [
          "glob": "",
          "headers": [],
          "regex": ""
        ]
      ],
      "i18n": ["root": ""],
      "redirects": [
        [
          "glob": "",
          "location": "",
          "regex": "",
          "statusCode": 0
        ]
      ],
      "rewrites": [
        [
          "dynamicLinks": false,
          "function": "",
          "functionRegion": "",
          "glob": "",
          "path": "",
          "regex": "",
          "run": [
            "region": "",
            "serviceId": ""
          ]
        ]
      ],
      "trailingSlashBehavior": ""
    ],
    "createTime": "",
    "createUser": [],
    "deleteTime": "",
    "deleteUser": [],
    "fileCount": "",
    "finalizeTime": "",
    "finalizeUser": [],
    "labels": [],
    "name": "",
    "status": "",
    "versionBytes": ""
  ]
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/releases")! 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 firebasehosting.sites.releases.list
{{baseUrl}}/v1beta1/:parent/releases
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

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

func main() {

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

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

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

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

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

}
GET /baseUrl/v1beta1/:parent/releases HTTP/1.1
Host: example.com

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

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

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

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

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

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

xhr.open('GET', '{{baseUrl}}/v1beta1/:parent/releases');

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

curl_close($curl);

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

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

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

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

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

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

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

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

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

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

response = requests.get(url)

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

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

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

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

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

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/releases")! 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 firebasehosting.sites.versions.clone
{{baseUrl}}/v1beta1/:parent/versions:clone
QUERY PARAMS

parent
BODY json

{
  "exclude": {
    "regexes": []
  },
  "finalize": false,
  "include": {},
  "sourceVersion": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:parent/versions:clone" {:content-type :json
                                                                           :form-params {:exclude {:regexes []}
                                                                                         :finalize false
                                                                                         :include {}
                                                                                         :sourceVersion ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/versions:clone"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}"

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

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

func main() {

	url := "{{baseUrl}}/v1beta1/:parent/versions:clone"

	payload := strings.NewReader("{\n  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}")

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

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

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

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

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

}
POST /baseUrl/v1beta1/:parent/versions:clone HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 101

{
  "exclude": {
    "regexes": []
  },
  "finalize": false,
  "include": {},
  "sourceVersion": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:parent/versions:clone")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:parent/versions:clone"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\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  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/versions:clone")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:parent/versions:clone")
  .header("content-type", "application/json")
  .body("{\n  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  exclude: {
    regexes: []
  },
  finalize: false,
  include: {},
  sourceVersion: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/versions:clone',
  headers: {'content-type': 'application/json'},
  data: {exclude: {regexes: []}, finalize: false, include: {}, sourceVersion: ''}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent/versions:clone';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"exclude":{"regexes":[]},"finalize":false,"include":{},"sourceVersion":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:parent/versions:clone',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "exclude": {\n    "regexes": []\n  },\n  "finalize": false,\n  "include": {},\n  "sourceVersion": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/versions:clone")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/:parent/versions:clone',
  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({exclude: {regexes: []}, finalize: false, include: {}, sourceVersion: ''}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/versions:clone',
  headers: {'content-type': 'application/json'},
  body: {exclude: {regexes: []}, finalize: false, include: {}, sourceVersion: ''},
  json: true
};

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

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

const req = unirest('POST', '{{baseUrl}}/v1beta1/:parent/versions:clone');

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

req.type('json');
req.send({
  exclude: {
    regexes: []
  },
  finalize: false,
  include: {},
  sourceVersion: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/versions:clone',
  headers: {'content-type': 'application/json'},
  data: {exclude: {regexes: []}, finalize: false, include: {}, sourceVersion: ''}
};

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

const url = '{{baseUrl}}/v1beta1/:parent/versions:clone';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"exclude":{"regexes":[]},"finalize":false,"include":{},"sourceVersion":""}'
};

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 = @{ @"exclude": @{ @"regexes": @[  ] },
                              @"finalize": @NO,
                              @"include": @{  },
                              @"sourceVersion": @"" };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:parent/versions:clone" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:parent/versions:clone",
  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([
    'exclude' => [
        'regexes' => [
                
        ]
    ],
    'finalize' => null,
    'include' => [
        
    ],
    'sourceVersion' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1beta1/:parent/versions:clone', [
  'body' => '{
  "exclude": {
    "regexes": []
  },
  "finalize": false,
  "include": {},
  "sourceVersion": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'exclude' => [
    'regexes' => [
        
    ]
  ],
  'finalize' => null,
  'include' => [
    
  ],
  'sourceVersion' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'exclude' => [
    'regexes' => [
        
    ]
  ],
  'finalize' => null,
  'include' => [
    
  ],
  'sourceVersion' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:parent/versions:clone');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:parent/versions:clone' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "exclude": {
    "regexes": []
  },
  "finalize": false,
  "include": {},
  "sourceVersion": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent/versions:clone' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "exclude": {
    "regexes": []
  },
  "finalize": false,
  "include": {},
  "sourceVersion": ""
}'
import http.client

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

payload = "{\n  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}"

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

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

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

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

url = "{{baseUrl}}/v1beta1/:parent/versions:clone"

payload = {
    "exclude": { "regexes": [] },
    "finalize": False,
    "include": {},
    "sourceVersion": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/v1beta1/:parent/versions:clone"

payload <- "{\n  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}"

encode <- "json"

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

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

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

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  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}"

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

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

response = conn.post('/baseUrl/v1beta1/:parent/versions:clone') do |req|
  req.body = "{\n  \"exclude\": {\n    \"regexes\": []\n  },\n  \"finalize\": false,\n  \"include\": {},\n  \"sourceVersion\": \"\"\n}"
end

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

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

    let payload = json!({
        "exclude": json!({"regexes": ()}),
        "finalize": false,
        "include": json!({}),
        "sourceVersion": ""
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1beta1/:parent/versions:clone \
  --header 'content-type: application/json' \
  --data '{
  "exclude": {
    "regexes": []
  },
  "finalize": false,
  "include": {},
  "sourceVersion": ""
}'
echo '{
  "exclude": {
    "regexes": []
  },
  "finalize": false,
  "include": {},
  "sourceVersion": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:parent/versions:clone \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "exclude": {\n    "regexes": []\n  },\n  "finalize": false,\n  "include": {},\n  "sourceVersion": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/versions:clone
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "exclude": ["regexes": []],
  "finalize": false,
  "include": [],
  "sourceVersion": ""
] as [String : Any]

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/versions:clone")! 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 firebasehosting.sites.versions.create
{{baseUrl}}/v1beta1/:parent/versions
QUERY PARAMS

parent
BODY json

{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}");

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

(client/post "{{baseUrl}}/v1beta1/:parent/versions" {:content-type :json
                                                                     :form-params {:config {:appAssociation ""
                                                                                            :cleanUrls false
                                                                                            :headers [{:glob ""
                                                                                                       :headers {}
                                                                                                       :regex ""}]
                                                                                            :i18n {:root ""}
                                                                                            :redirects [{:glob ""
                                                                                                         :location ""
                                                                                                         :regex ""
                                                                                                         :statusCode 0}]
                                                                                            :rewrites [{:dynamicLinks false
                                                                                                        :function ""
                                                                                                        :functionRegion ""
                                                                                                        :glob ""
                                                                                                        :path ""
                                                                                                        :regex ""
                                                                                                        :run {:region ""
                                                                                                              :serviceId ""}}]
                                                                                            :trailingSlashBehavior ""}
                                                                                   :createTime ""
                                                                                   :createUser {:email ""
                                                                                                :imageUrl ""}
                                                                                   :deleteTime ""
                                                                                   :deleteUser {}
                                                                                   :fileCount ""
                                                                                   :finalizeTime ""
                                                                                   :finalizeUser {}
                                                                                   :labels {}
                                                                                   :name ""
                                                                                   :status ""
                                                                                   :versionBytes ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/versions"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1beta1/:parent/versions"),
    Content = new StringContent("{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/:parent/versions");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

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

	payload := strings.NewReader("{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}")

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

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

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

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

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

}
POST /baseUrl/v1beta1/:parent/versions HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 889

{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:parent/versions")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:parent/versions"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\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  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/versions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:parent/versions")
  .header("content-type", "application/json")
  .body("{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  config: {
    appAssociation: '',
    cleanUrls: false,
    headers: [
      {
        glob: '',
        headers: {},
        regex: ''
      }
    ],
    i18n: {
      root: ''
    },
    redirects: [
      {
        glob: '',
        location: '',
        regex: '',
        statusCode: 0
      }
    ],
    rewrites: [
      {
        dynamicLinks: false,
        function: '',
        functionRegion: '',
        glob: '',
        path: '',
        regex: '',
        run: {
          region: '',
          serviceId: ''
        }
      }
    ],
    trailingSlashBehavior: ''
  },
  createTime: '',
  createUser: {
    email: '',
    imageUrl: ''
  },
  deleteTime: '',
  deleteUser: {},
  fileCount: '',
  finalizeTime: '',
  finalizeUser: {},
  labels: {},
  name: '',
  status: '',
  versionBytes: ''
});

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

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

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/versions',
  headers: {'content-type': 'application/json'},
  data: {
    config: {
      appAssociation: '',
      cleanUrls: false,
      headers: [{glob: '', headers: {}, regex: ''}],
      i18n: {root: ''},
      redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
      rewrites: [
        {
          dynamicLinks: false,
          function: '',
          functionRegion: '',
          glob: '',
          path: '',
          regex: '',
          run: {region: '', serviceId: ''}
        }
      ],
      trailingSlashBehavior: ''
    },
    createTime: '',
    createUser: {email: '', imageUrl: ''},
    deleteTime: '',
    deleteUser: {},
    fileCount: '',
    finalizeTime: '',
    finalizeUser: {},
    labels: {},
    name: '',
    status: '',
    versionBytes: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent/versions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"config":{"appAssociation":"","cleanUrls":false,"headers":[{"glob":"","headers":{},"regex":""}],"i18n":{"root":""},"redirects":[{"glob":"","location":"","regex":"","statusCode":0}],"rewrites":[{"dynamicLinks":false,"function":"","functionRegion":"","glob":"","path":"","regex":"","run":{"region":"","serviceId":""}}],"trailingSlashBehavior":""},"createTime":"","createUser":{"email":"","imageUrl":""},"deleteTime":"","deleteUser":{},"fileCount":"","finalizeTime":"","finalizeUser":{},"labels":{},"name":"","status":"","versionBytes":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:parent/versions',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "config": {\n    "appAssociation": "",\n    "cleanUrls": false,\n    "headers": [\n      {\n        "glob": "",\n        "headers": {},\n        "regex": ""\n      }\n    ],\n    "i18n": {\n      "root": ""\n    },\n    "redirects": [\n      {\n        "glob": "",\n        "location": "",\n        "regex": "",\n        "statusCode": 0\n      }\n    ],\n    "rewrites": [\n      {\n        "dynamicLinks": false,\n        "function": "",\n        "functionRegion": "",\n        "glob": "",\n        "path": "",\n        "regex": "",\n        "run": {\n          "region": "",\n          "serviceId": ""\n        }\n      }\n    ],\n    "trailingSlashBehavior": ""\n  },\n  "createTime": "",\n  "createUser": {\n    "email": "",\n    "imageUrl": ""\n  },\n  "deleteTime": "",\n  "deleteUser": {},\n  "fileCount": "",\n  "finalizeTime": "",\n  "finalizeUser": {},\n  "labels": {},\n  "name": "",\n  "status": "",\n  "versionBytes": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/versions")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

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

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

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

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

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

req.write(JSON.stringify({
  config: {
    appAssociation: '',
    cleanUrls: false,
    headers: [{glob: '', headers: {}, regex: ''}],
    i18n: {root: ''},
    redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
    rewrites: [
      {
        dynamicLinks: false,
        function: '',
        functionRegion: '',
        glob: '',
        path: '',
        regex: '',
        run: {region: '', serviceId: ''}
      }
    ],
    trailingSlashBehavior: ''
  },
  createTime: '',
  createUser: {email: '', imageUrl: ''},
  deleteTime: '',
  deleteUser: {},
  fileCount: '',
  finalizeTime: '',
  finalizeUser: {},
  labels: {},
  name: '',
  status: '',
  versionBytes: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/versions',
  headers: {'content-type': 'application/json'},
  body: {
    config: {
      appAssociation: '',
      cleanUrls: false,
      headers: [{glob: '', headers: {}, regex: ''}],
      i18n: {root: ''},
      redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
      rewrites: [
        {
          dynamicLinks: false,
          function: '',
          functionRegion: '',
          glob: '',
          path: '',
          regex: '',
          run: {region: '', serviceId: ''}
        }
      ],
      trailingSlashBehavior: ''
    },
    createTime: '',
    createUser: {email: '', imageUrl: ''},
    deleteTime: '',
    deleteUser: {},
    fileCount: '',
    finalizeTime: '',
    finalizeUser: {},
    labels: {},
    name: '',
    status: '',
    versionBytes: ''
  },
  json: true
};

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

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

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

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

req.type('json');
req.send({
  config: {
    appAssociation: '',
    cleanUrls: false,
    headers: [
      {
        glob: '',
        headers: {},
        regex: ''
      }
    ],
    i18n: {
      root: ''
    },
    redirects: [
      {
        glob: '',
        location: '',
        regex: '',
        statusCode: 0
      }
    ],
    rewrites: [
      {
        dynamicLinks: false,
        function: '',
        functionRegion: '',
        glob: '',
        path: '',
        regex: '',
        run: {
          region: '',
          serviceId: ''
        }
      }
    ],
    trailingSlashBehavior: ''
  },
  createTime: '',
  createUser: {
    email: '',
    imageUrl: ''
  },
  deleteTime: '',
  deleteUser: {},
  fileCount: '',
  finalizeTime: '',
  finalizeUser: {},
  labels: {},
  name: '',
  status: '',
  versionBytes: ''
});

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

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

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent/versions',
  headers: {'content-type': 'application/json'},
  data: {
    config: {
      appAssociation: '',
      cleanUrls: false,
      headers: [{glob: '', headers: {}, regex: ''}],
      i18n: {root: ''},
      redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
      rewrites: [
        {
          dynamicLinks: false,
          function: '',
          functionRegion: '',
          glob: '',
          path: '',
          regex: '',
          run: {region: '', serviceId: ''}
        }
      ],
      trailingSlashBehavior: ''
    },
    createTime: '',
    createUser: {email: '', imageUrl: ''},
    deleteTime: '',
    deleteUser: {},
    fileCount: '',
    finalizeTime: '',
    finalizeUser: {},
    labels: {},
    name: '',
    status: '',
    versionBytes: ''
  }
};

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

const url = '{{baseUrl}}/v1beta1/:parent/versions';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"config":{"appAssociation":"","cleanUrls":false,"headers":[{"glob":"","headers":{},"regex":""}],"i18n":{"root":""},"redirects":[{"glob":"","location":"","regex":"","statusCode":0}],"rewrites":[{"dynamicLinks":false,"function":"","functionRegion":"","glob":"","path":"","regex":"","run":{"region":"","serviceId":""}}],"trailingSlashBehavior":""},"createTime":"","createUser":{"email":"","imageUrl":""},"deleteTime":"","deleteUser":{},"fileCount":"","finalizeTime":"","finalizeUser":{},"labels":{},"name":"","status":"","versionBytes":""}'
};

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 = @{ @"config": @{ @"appAssociation": @"", @"cleanUrls": @NO, @"headers": @[ @{ @"glob": @"", @"headers": @{  }, @"regex": @"" } ], @"i18n": @{ @"root": @"" }, @"redirects": @[ @{ @"glob": @"", @"location": @"", @"regex": @"", @"statusCode": @0 } ], @"rewrites": @[ @{ @"dynamicLinks": @NO, @"function": @"", @"functionRegion": @"", @"glob": @"", @"path": @"", @"regex": @"", @"run": @{ @"region": @"", @"serviceId": @"" } } ], @"trailingSlashBehavior": @"" },
                              @"createTime": @"",
                              @"createUser": @{ @"email": @"", @"imageUrl": @"" },
                              @"deleteTime": @"",
                              @"deleteUser": @{  },
                              @"fileCount": @"",
                              @"finalizeTime": @"",
                              @"finalizeUser": @{  },
                              @"labels": @{  },
                              @"name": @"",
                              @"status": @"",
                              @"versionBytes": @"" };

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

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

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

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:parent/versions" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:parent/versions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "POST",
  CURLOPT_POSTFIELDS => json_encode([
    'config' => [
        'appAssociation' => '',
        'cleanUrls' => null,
        'headers' => [
                [
                                'glob' => '',
                                'headers' => [
                                                                
                                ],
                                'regex' => ''
                ]
        ],
        'i18n' => [
                'root' => ''
        ],
        'redirects' => [
                [
                                'glob' => '',
                                'location' => '',
                                'regex' => '',
                                'statusCode' => 0
                ]
        ],
        'rewrites' => [
                [
                                'dynamicLinks' => null,
                                'function' => '',
                                'functionRegion' => '',
                                'glob' => '',
                                'path' => '',
                                'regex' => '',
                                'run' => [
                                                                'region' => '',
                                                                'serviceId' => ''
                                ]
                ]
        ],
        'trailingSlashBehavior' => ''
    ],
    'createTime' => '',
    'createUser' => [
        'email' => '',
        'imageUrl' => ''
    ],
    'deleteTime' => '',
    'deleteUser' => [
        
    ],
    'fileCount' => '',
    'finalizeTime' => '',
    'finalizeUser' => [
        
    ],
    'labels' => [
        
    ],
    'name' => '',
    'status' => '',
    'versionBytes' => ''
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

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

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1beta1/:parent/versions', [
  'body' => '{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'config' => [
    'appAssociation' => '',
    'cleanUrls' => null,
    'headers' => [
        [
                'glob' => '',
                'headers' => [
                                
                ],
                'regex' => ''
        ]
    ],
    'i18n' => [
        'root' => ''
    ],
    'redirects' => [
        [
                'glob' => '',
                'location' => '',
                'regex' => '',
                'statusCode' => 0
        ]
    ],
    'rewrites' => [
        [
                'dynamicLinks' => null,
                'function' => '',
                'functionRegion' => '',
                'glob' => '',
                'path' => '',
                'regex' => '',
                'run' => [
                                'region' => '',
                                'serviceId' => ''
                ]
        ]
    ],
    'trailingSlashBehavior' => ''
  ],
  'createTime' => '',
  'createUser' => [
    'email' => '',
    'imageUrl' => ''
  ],
  'deleteTime' => '',
  'deleteUser' => [
    
  ],
  'fileCount' => '',
  'finalizeTime' => '',
  'finalizeUser' => [
    
  ],
  'labels' => [
    
  ],
  'name' => '',
  'status' => '',
  'versionBytes' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'config' => [
    'appAssociation' => '',
    'cleanUrls' => null,
    'headers' => [
        [
                'glob' => '',
                'headers' => [
                                
                ],
                'regex' => ''
        ]
    ],
    'i18n' => [
        'root' => ''
    ],
    'redirects' => [
        [
                'glob' => '',
                'location' => '',
                'regex' => '',
                'statusCode' => 0
        ]
    ],
    'rewrites' => [
        [
                'dynamicLinks' => null,
                'function' => '',
                'functionRegion' => '',
                'glob' => '',
                'path' => '',
                'regex' => '',
                'run' => [
                                'region' => '',
                                'serviceId' => ''
                ]
        ]
    ],
    'trailingSlashBehavior' => ''
  ],
  'createTime' => '',
  'createUser' => [
    'email' => '',
    'imageUrl' => ''
  ],
  'deleteTime' => '',
  'deleteUser' => [
    
  ],
  'fileCount' => '',
  'finalizeTime' => '',
  'finalizeUser' => [
    
  ],
  'labels' => [
    
  ],
  'name' => '',
  'status' => '',
  'versionBytes' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:parent/versions');
$request->setRequestMethod('POST');
$request->setBody($body);

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

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

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:parent/versions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent/versions' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}'
import http.client

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

payload = "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}"

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

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

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

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

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

payload = {
    "config": {
        "appAssociation": "",
        "cleanUrls": False,
        "headers": [
            {
                "glob": "",
                "headers": {},
                "regex": ""
            }
        ],
        "i18n": { "root": "" },
        "redirects": [
            {
                "glob": "",
                "location": "",
                "regex": "",
                "statusCode": 0
            }
        ],
        "rewrites": [
            {
                "dynamicLinks": False,
                "function": "",
                "functionRegion": "",
                "glob": "",
                "path": "",
                "regex": "",
                "run": {
                    "region": "",
                    "serviceId": ""
                }
            }
        ],
        "trailingSlashBehavior": ""
    },
    "createTime": "",
    "createUser": {
        "email": "",
        "imageUrl": ""
    },
    "deleteTime": "",
    "deleteUser": {},
    "fileCount": "",
    "finalizeTime": "",
    "finalizeUser": {},
    "labels": {},
    "name": "",
    "status": "",
    "versionBytes": ""
}
headers = {"content-type": "application/json"}

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

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

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

payload <- "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}"

encode <- "json"

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

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

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

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

request = Net::HTTP::Post.new(url)
request["content-type"] = 'application/json'
request.body = "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}"

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

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

response = conn.post('/baseUrl/v1beta1/:parent/versions') do |req|
  req.body = "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}"
end

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

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

    let payload = json!({
        "config": json!({
            "appAssociation": "",
            "cleanUrls": false,
            "headers": (
                json!({
                    "glob": "",
                    "headers": json!({}),
                    "regex": ""
                })
            ),
            "i18n": json!({"root": ""}),
            "redirects": (
                json!({
                    "glob": "",
                    "location": "",
                    "regex": "",
                    "statusCode": 0
                })
            ),
            "rewrites": (
                json!({
                    "dynamicLinks": false,
                    "function": "",
                    "functionRegion": "",
                    "glob": "",
                    "path": "",
                    "regex": "",
                    "run": json!({
                        "region": "",
                        "serviceId": ""
                    })
                })
            ),
            "trailingSlashBehavior": ""
        }),
        "createTime": "",
        "createUser": json!({
            "email": "",
            "imageUrl": ""
        }),
        "deleteTime": "",
        "deleteUser": json!({}),
        "fileCount": "",
        "finalizeTime": "",
        "finalizeUser": json!({}),
        "labels": json!({}),
        "name": "",
        "status": "",
        "versionBytes": ""
    });

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

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

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

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1beta1/:parent/versions \
  --header 'content-type: application/json' \
  --data '{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}'
echo '{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}' |  \
  http POST {{baseUrl}}/v1beta1/:parent/versions \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "config": {\n    "appAssociation": "",\n    "cleanUrls": false,\n    "headers": [\n      {\n        "glob": "",\n        "headers": {},\n        "regex": ""\n      }\n    ],\n    "i18n": {\n      "root": ""\n    },\n    "redirects": [\n      {\n        "glob": "",\n        "location": "",\n        "regex": "",\n        "statusCode": 0\n      }\n    ],\n    "rewrites": [\n      {\n        "dynamicLinks": false,\n        "function": "",\n        "functionRegion": "",\n        "glob": "",\n        "path": "",\n        "regex": "",\n        "run": {\n          "region": "",\n          "serviceId": ""\n        }\n      }\n    ],\n    "trailingSlashBehavior": ""\n  },\n  "createTime": "",\n  "createUser": {\n    "email": "",\n    "imageUrl": ""\n  },\n  "deleteTime": "",\n  "deleteUser": {},\n  "fileCount": "",\n  "finalizeTime": "",\n  "finalizeUser": {},\n  "labels": {},\n  "name": "",\n  "status": "",\n  "versionBytes": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/versions
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "config": [
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      [
        "glob": "",
        "headers": [],
        "regex": ""
      ]
    ],
    "i18n": ["root": ""],
    "redirects": [
      [
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      ]
    ],
    "rewrites": [
      [
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": [
          "region": "",
          "serviceId": ""
        ]
      ]
    ],
    "trailingSlashBehavior": ""
  ],
  "createTime": "",
  "createUser": [
    "email": "",
    "imageUrl": ""
  ],
  "deleteTime": "",
  "deleteUser": [],
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": [],
  "labels": [],
  "name": "",
  "status": "",
  "versionBytes": ""
] as [String : Any]

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

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

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

dataTask.resume()
DELETE firebasehosting.sites.versions.delete
{{baseUrl}}/v1beta1/:name
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

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

func main() {

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

curl_close($curl);

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

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

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

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

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

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

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

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

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

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

response = requests.delete(url)

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

dataTask.resume()
GET firebasehosting.sites.versions.files.list
{{baseUrl}}/v1beta1/:parent/files
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

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

func main() {

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

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

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

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

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

}
GET /baseUrl/v1beta1/:parent/files HTTP/1.1
Host: example.com

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

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

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

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

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

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

xhr.open('GET', '{{baseUrl}}/v1beta1/:parent/files');

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

curl_close($curl);

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

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

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

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

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

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

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

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

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

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

response = requests.get(url)

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

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

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

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

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

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

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

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

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

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

puts response.status
puts response.body
use reqwest;

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

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

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/files")! 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 firebasehosting.sites.versions.get
{{baseUrl}}/v1beta1/:name
QUERY PARAMS

name
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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

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

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

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

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

func main() {

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/:name';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:name" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v1beta1/:name');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/:name');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/:name');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:name' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/:name")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/:name"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/:name"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/:name")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/v1beta1/:name') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/:name";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v1beta1/:name
http GET {{baseUrl}}/v1beta1/:name
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/:name
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
GET firebasehosting.sites.versions.list
{{baseUrl}}/v1beta1/:parent/versions
QUERY PARAMS

parent
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/:parent/versions");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/get "{{baseUrl}}/v1beta1/:parent/versions")
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent/versions"

response = HTTP::Client.get url
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Get,
    RequestUri = new Uri("{{baseUrl}}/v1beta1/:parent/versions"),
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/:parent/versions");
var request = new RestRequest("", Method.Get);
var response = client.Execute(request);
package main

import (
	"fmt"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/:parent/versions"

	req, _ := http.NewRequest("GET", url, nil)

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
GET /baseUrl/v1beta1/:parent/versions HTTP/1.1
Host: example.com

AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("GET", "{{baseUrl}}/v1beta1/:parent/versions")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:parent/versions"))
    .method("GET", HttpRequest.BodyPublishers.noBody())
    .build();
HttpResponse response = HttpClient.newHttpClient().send(request, HttpResponse.BodyHandlers.ofString());
System.out.println(response.body());
OkHttpClient client = new OkHttpClient();

Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/versions")
  .get()
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.get("{{baseUrl}}/v1beta1/:parent/versions")
  .asString();
const data = null;

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('GET', '{{baseUrl}}/v1beta1/:parent/versions');

xhr.send(data);
import axios from 'axios';

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/versions'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent/versions';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:parent/versions',
  method: 'GET',
  headers: {}
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent/versions")
  .get()
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'GET',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/:parent/versions',
  headers: {}
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.end();
const request = require('request');

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/versions'};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('GET', '{{baseUrl}}/v1beta1/:parent/versions');

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {method: 'GET', url: '{{baseUrl}}/v1beta1/:parent/versions'};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/:parent/versions';
const options = {method: 'GET'};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
#import 

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:parent/versions"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"GET"];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:parent/versions" in

Client.call `GET uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:parent/versions",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "GET",
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('GET', '{{baseUrl}}/v1beta1/:parent/versions');

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/:parent/versions');
$request->setMethod(HTTP_METH_GET);

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
setRequestUrl('{{baseUrl}}/v1beta1/:parent/versions');
$request->setRequestMethod('GET');
$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:parent/versions' -Method GET 
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent/versions' -Method GET 
import http.client

conn = http.client.HTTPSConnection("example.com")

conn.request("GET", "/baseUrl/v1beta1/:parent/versions")

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/:parent/versions"

response = requests.get(url)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/:parent/versions"

response <- VERB("GET", url, content_type("application/octet-stream"))

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/:parent/versions")

http = Net::HTTP.new(url.host, url.port)
http.use_ssl = true

request = Net::HTTP::Get.new(url)

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
)

response = conn.get('/baseUrl/v1beta1/:parent/versions') do |req|
end

puts response.status
puts response.body
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/:parent/versions";

    let client = reqwest::Client::new();
    let response = client.get(url)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request GET \
  --url {{baseUrl}}/v1beta1/:parent/versions
http GET {{baseUrl}}/v1beta1/:parent/versions
wget --quiet \
  --method GET \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent/versions
import Foundation

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent/versions")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "GET"

let session = URLSession.shared
let dataTask = session.dataTask(with: request as URLRequest, completionHandler: { (data, response, error) -> Void in
  if (error != nil) {
    print(error as Any)
  } else {
    let httpResponse = response as? HTTPURLResponse
    print(httpResponse)
  }
})

dataTask.resume()
PATCH firebasehosting.sites.versions.patch
{{baseUrl}}/v1beta1/:name
QUERY PARAMS

name
BODY json

{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "PATCH");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/:name");

struct curl_slist *headers = NULL;
headers = curl_slist_append(headers, "content-type: application/json");
curl_easy_setopt(hnd, CURLOPT_HTTPHEADER, headers);

curl_easy_setopt(hnd, CURLOPT_POSTFIELDS, "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/patch "{{baseUrl}}/v1beta1/:name" {:content-type :json
                                                           :form-params {:config {:appAssociation ""
                                                                                  :cleanUrls false
                                                                                  :headers [{:glob ""
                                                                                             :headers {}
                                                                                             :regex ""}]
                                                                                  :i18n {:root ""}
                                                                                  :redirects [{:glob ""
                                                                                               :location ""
                                                                                               :regex ""
                                                                                               :statusCode 0}]
                                                                                  :rewrites [{:dynamicLinks false
                                                                                              :function ""
                                                                                              :functionRegion ""
                                                                                              :glob ""
                                                                                              :path ""
                                                                                              :regex ""
                                                                                              :run {:region ""
                                                                                                    :serviceId ""}}]
                                                                                  :trailingSlashBehavior ""}
                                                                         :createTime ""
                                                                         :createUser {:email ""
                                                                                      :imageUrl ""}
                                                                         :deleteTime ""
                                                                         :deleteUser {}
                                                                         :fileCount ""
                                                                         :finalizeTime ""
                                                                         :finalizeUser {}
                                                                         :labels {}
                                                                         :name ""
                                                                         :status ""
                                                                         :versionBytes ""}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:name"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\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}}/v1beta1/:name"),
    Content = new StringContent("{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/:name");
var request = new RestRequest("", Method.Patch);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/:name"

	payload := strings.NewReader("{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\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/v1beta1/:name HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 889

{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/v1beta1/:name")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:name"))
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\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  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:name")
  .patch(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/v1beta1/:name")
  .header("content-type", "application/json")
  .body("{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  config: {
    appAssociation: '',
    cleanUrls: false,
    headers: [
      {
        glob: '',
        headers: {},
        regex: ''
      }
    ],
    i18n: {
      root: ''
    },
    redirects: [
      {
        glob: '',
        location: '',
        regex: '',
        statusCode: 0
      }
    ],
    rewrites: [
      {
        dynamicLinks: false,
        function: '',
        functionRegion: '',
        glob: '',
        path: '',
        regex: '',
        run: {
          region: '',
          serviceId: ''
        }
      }
    ],
    trailingSlashBehavior: ''
  },
  createTime: '',
  createUser: {
    email: '',
    imageUrl: ''
  },
  deleteTime: '',
  deleteUser: {},
  fileCount: '',
  finalizeTime: '',
  finalizeUser: {},
  labels: {},
  name: '',
  status: '',
  versionBytes: ''
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('PATCH', '{{baseUrl}}/v1beta1/:name');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/v1beta1/:name',
  headers: {'content-type': 'application/json'},
  data: {
    config: {
      appAssociation: '',
      cleanUrls: false,
      headers: [{glob: '', headers: {}, regex: ''}],
      i18n: {root: ''},
      redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
      rewrites: [
        {
          dynamicLinks: false,
          function: '',
          functionRegion: '',
          glob: '',
          path: '',
          regex: '',
          run: {region: '', serviceId: ''}
        }
      ],
      trailingSlashBehavior: ''
    },
    createTime: '',
    createUser: {email: '', imageUrl: ''},
    deleteTime: '',
    deleteUser: {},
    fileCount: '',
    finalizeTime: '',
    finalizeUser: {},
    labels: {},
    name: '',
    status: '',
    versionBytes: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:name';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"config":{"appAssociation":"","cleanUrls":false,"headers":[{"glob":"","headers":{},"regex":""}],"i18n":{"root":""},"redirects":[{"glob":"","location":"","regex":"","statusCode":0}],"rewrites":[{"dynamicLinks":false,"function":"","functionRegion":"","glob":"","path":"","regex":"","run":{"region":"","serviceId":""}}],"trailingSlashBehavior":""},"createTime":"","createUser":{"email":"","imageUrl":""},"deleteTime":"","deleteUser":{},"fileCount":"","finalizeTime":"","finalizeUser":{},"labels":{},"name":"","status":"","versionBytes":""}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:name',
  method: 'PATCH',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "config": {\n    "appAssociation": "",\n    "cleanUrls": false,\n    "headers": [\n      {\n        "glob": "",\n        "headers": {},\n        "regex": ""\n      }\n    ],\n    "i18n": {\n      "root": ""\n    },\n    "redirects": [\n      {\n        "glob": "",\n        "location": "",\n        "regex": "",\n        "statusCode": 0\n      }\n    ],\n    "rewrites": [\n      {\n        "dynamicLinks": false,\n        "function": "",\n        "functionRegion": "",\n        "glob": "",\n        "path": "",\n        "regex": "",\n        "run": {\n          "region": "",\n          "serviceId": ""\n        }\n      }\n    ],\n    "trailingSlashBehavior": ""\n  },\n  "createTime": "",\n  "createUser": {\n    "email": "",\n    "imageUrl": ""\n  },\n  "deleteTime": "",\n  "deleteUser": {},\n  "fileCount": "",\n  "finalizeTime": "",\n  "finalizeUser": {},\n  "labels": {},\n  "name": "",\n  "status": "",\n  "versionBytes": ""\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/: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/v1beta1/:name',
  headers: {
    'content-type': 'application/json'
  }
};

const req = http.request(options, function (res) {
  const chunks = [];

  res.on('data', function (chunk) {
    chunks.push(chunk);
  });

  res.on('end', function () {
    const body = Buffer.concat(chunks);
    console.log(body.toString());
  });
});

req.write(JSON.stringify({
  config: {
    appAssociation: '',
    cleanUrls: false,
    headers: [{glob: '', headers: {}, regex: ''}],
    i18n: {root: ''},
    redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
    rewrites: [
      {
        dynamicLinks: false,
        function: '',
        functionRegion: '',
        glob: '',
        path: '',
        regex: '',
        run: {region: '', serviceId: ''}
      }
    ],
    trailingSlashBehavior: ''
  },
  createTime: '',
  createUser: {email: '', imageUrl: ''},
  deleteTime: '',
  deleteUser: {},
  fileCount: '',
  finalizeTime: '',
  finalizeUser: {},
  labels: {},
  name: '',
  status: '',
  versionBytes: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/v1beta1/:name',
  headers: {'content-type': 'application/json'},
  body: {
    config: {
      appAssociation: '',
      cleanUrls: false,
      headers: [{glob: '', headers: {}, regex: ''}],
      i18n: {root: ''},
      redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
      rewrites: [
        {
          dynamicLinks: false,
          function: '',
          functionRegion: '',
          glob: '',
          path: '',
          regex: '',
          run: {region: '', serviceId: ''}
        }
      ],
      trailingSlashBehavior: ''
    },
    createTime: '',
    createUser: {email: '', imageUrl: ''},
    deleteTime: '',
    deleteUser: {},
    fileCount: '',
    finalizeTime: '',
    finalizeUser: {},
    labels: {},
    name: '',
    status: '',
    versionBytes: ''
  },
  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}}/v1beta1/:name');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  config: {
    appAssociation: '',
    cleanUrls: false,
    headers: [
      {
        glob: '',
        headers: {},
        regex: ''
      }
    ],
    i18n: {
      root: ''
    },
    redirects: [
      {
        glob: '',
        location: '',
        regex: '',
        statusCode: 0
      }
    ],
    rewrites: [
      {
        dynamicLinks: false,
        function: '',
        functionRegion: '',
        glob: '',
        path: '',
        regex: '',
        run: {
          region: '',
          serviceId: ''
        }
      }
    ],
    trailingSlashBehavior: ''
  },
  createTime: '',
  createUser: {
    email: '',
    imageUrl: ''
  },
  deleteTime: '',
  deleteUser: {},
  fileCount: '',
  finalizeTime: '',
  finalizeUser: {},
  labels: {},
  name: '',
  status: '',
  versionBytes: ''
});

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}}/v1beta1/:name',
  headers: {'content-type': 'application/json'},
  data: {
    config: {
      appAssociation: '',
      cleanUrls: false,
      headers: [{glob: '', headers: {}, regex: ''}],
      i18n: {root: ''},
      redirects: [{glob: '', location: '', regex: '', statusCode: 0}],
      rewrites: [
        {
          dynamicLinks: false,
          function: '',
          functionRegion: '',
          glob: '',
          path: '',
          regex: '',
          run: {region: '', serviceId: ''}
        }
      ],
      trailingSlashBehavior: ''
    },
    createTime: '',
    createUser: {email: '', imageUrl: ''},
    deleteTime: '',
    deleteUser: {},
    fileCount: '',
    finalizeTime: '',
    finalizeUser: {},
    labels: {},
    name: '',
    status: '',
    versionBytes: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/:name';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"config":{"appAssociation":"","cleanUrls":false,"headers":[{"glob":"","headers":{},"regex":""}],"i18n":{"root":""},"redirects":[{"glob":"","location":"","regex":"","statusCode":0}],"rewrites":[{"dynamicLinks":false,"function":"","functionRegion":"","glob":"","path":"","regex":"","run":{"region":"","serviceId":""}}],"trailingSlashBehavior":""},"createTime":"","createUser":{"email":"","imageUrl":""},"deleteTime":"","deleteUser":{},"fileCount":"","finalizeTime":"","finalizeUser":{},"labels":{},"name":"","status":"","versionBytes":""}'
};

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 = @{ @"config": @{ @"appAssociation": @"", @"cleanUrls": @NO, @"headers": @[ @{ @"glob": @"", @"headers": @{  }, @"regex": @"" } ], @"i18n": @{ @"root": @"" }, @"redirects": @[ @{ @"glob": @"", @"location": @"", @"regex": @"", @"statusCode": @0 } ], @"rewrites": @[ @{ @"dynamicLinks": @NO, @"function": @"", @"functionRegion": @"", @"glob": @"", @"path": @"", @"regex": @"", @"run": @{ @"region": @"", @"serviceId": @"" } } ], @"trailingSlashBehavior": @"" },
                              @"createTime": @"",
                              @"createUser": @{ @"email": @"", @"imageUrl": @"" },
                              @"deleteTime": @"",
                              @"deleteUser": @{  },
                              @"fileCount": @"",
                              @"finalizeTime": @"",
                              @"finalizeUser": @{  },
                              @"labels": @{  },
                              @"name": @"",
                              @"status": @"",
                              @"versionBytes": @"" };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:name"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"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}}/v1beta1/:name" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:name",
  CURLOPT_RETURNTRANSFER => true,
  CURLOPT_ENCODING => "",
  CURLOPT_MAXREDIRS => 10,
  CURLOPT_TIMEOUT => 30,
  CURLOPT_HTTP_VERSION => CURL_HTTP_VERSION_1_1,
  CURLOPT_CUSTOMREQUEST => "PATCH",
  CURLOPT_POSTFIELDS => json_encode([
    'config' => [
        'appAssociation' => '',
        'cleanUrls' => null,
        'headers' => [
                [
                                'glob' => '',
                                'headers' => [
                                                                
                                ],
                                'regex' => ''
                ]
        ],
        'i18n' => [
                'root' => ''
        ],
        'redirects' => [
                [
                                'glob' => '',
                                'location' => '',
                                'regex' => '',
                                'statusCode' => 0
                ]
        ],
        'rewrites' => [
                [
                                'dynamicLinks' => null,
                                'function' => '',
                                'functionRegion' => '',
                                'glob' => '',
                                'path' => '',
                                'regex' => '',
                                'run' => [
                                                                'region' => '',
                                                                'serviceId' => ''
                                ]
                ]
        ],
        'trailingSlashBehavior' => ''
    ],
    'createTime' => '',
    'createUser' => [
        'email' => '',
        'imageUrl' => ''
    ],
    'deleteTime' => '',
    'deleteUser' => [
        
    ],
    'fileCount' => '',
    'finalizeTime' => '',
    'finalizeUser' => [
        
    ],
    'labels' => [
        
    ],
    'name' => '',
    'status' => '',
    'versionBytes' => ''
  ]),
  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}}/v1beta1/:name', [
  'body' => '{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/:name');
$request->setMethod(HttpRequest::HTTP_METH_PATCH);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'config' => [
    'appAssociation' => '',
    'cleanUrls' => null,
    'headers' => [
        [
                'glob' => '',
                'headers' => [
                                
                ],
                'regex' => ''
        ]
    ],
    'i18n' => [
        'root' => ''
    ],
    'redirects' => [
        [
                'glob' => '',
                'location' => '',
                'regex' => '',
                'statusCode' => 0
        ]
    ],
    'rewrites' => [
        [
                'dynamicLinks' => null,
                'function' => '',
                'functionRegion' => '',
                'glob' => '',
                'path' => '',
                'regex' => '',
                'run' => [
                                'region' => '',
                                'serviceId' => ''
                ]
        ]
    ],
    'trailingSlashBehavior' => ''
  ],
  'createTime' => '',
  'createUser' => [
    'email' => '',
    'imageUrl' => ''
  ],
  'deleteTime' => '',
  'deleteUser' => [
    
  ],
  'fileCount' => '',
  'finalizeTime' => '',
  'finalizeUser' => [
    
  ],
  'labels' => [
    
  ],
  'name' => '',
  'status' => '',
  'versionBytes' => ''
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'config' => [
    'appAssociation' => '',
    'cleanUrls' => null,
    'headers' => [
        [
                'glob' => '',
                'headers' => [
                                
                ],
                'regex' => ''
        ]
    ],
    'i18n' => [
        'root' => ''
    ],
    'redirects' => [
        [
                'glob' => '',
                'location' => '',
                'regex' => '',
                'statusCode' => 0
        ]
    ],
    'rewrites' => [
        [
                'dynamicLinks' => null,
                'function' => '',
                'functionRegion' => '',
                'glob' => '',
                'path' => '',
                'regex' => '',
                'run' => [
                                'region' => '',
                                'serviceId' => ''
                ]
        ]
    ],
    'trailingSlashBehavior' => ''
  ],
  'createTime' => '',
  'createUser' => [
    'email' => '',
    'imageUrl' => ''
  ],
  'deleteTime' => '',
  'deleteUser' => [
    
  ],
  'fileCount' => '',
  'finalizeTime' => '',
  'finalizeUser' => [
    
  ],
  'labels' => [
    
  ],
  'name' => '',
  'status' => '',
  'versionBytes' => ''
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/: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}}/v1beta1/:name' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:name' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}"

headers = { 'content-type': "application/json" }

conn.request("PATCH", "/baseUrl/v1beta1/:name", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/:name"

payload = {
    "config": {
        "appAssociation": "",
        "cleanUrls": False,
        "headers": [
            {
                "glob": "",
                "headers": {},
                "regex": ""
            }
        ],
        "i18n": { "root": "" },
        "redirects": [
            {
                "glob": "",
                "location": "",
                "regex": "",
                "statusCode": 0
            }
        ],
        "rewrites": [
            {
                "dynamicLinks": False,
                "function": "",
                "functionRegion": "",
                "glob": "",
                "path": "",
                "regex": "",
                "run": {
                    "region": "",
                    "serviceId": ""
                }
            }
        ],
        "trailingSlashBehavior": ""
    },
    "createTime": "",
    "createUser": {
        "email": "",
        "imageUrl": ""
    },
    "deleteTime": "",
    "deleteUser": {},
    "fileCount": "",
    "finalizeTime": "",
    "finalizeUser": {},
    "labels": {},
    "name": "",
    "status": "",
    "versionBytes": ""
}
headers = {"content-type": "application/json"}

response = requests.patch(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/:name"

payload <- "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\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}}/v1beta1/: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  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\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/v1beta1/:name') do |req|
  req.body = "{\n  \"config\": {\n    \"appAssociation\": \"\",\n    \"cleanUrls\": false,\n    \"headers\": [\n      {\n        \"glob\": \"\",\n        \"headers\": {},\n        \"regex\": \"\"\n      }\n    ],\n    \"i18n\": {\n      \"root\": \"\"\n    },\n    \"redirects\": [\n      {\n        \"glob\": \"\",\n        \"location\": \"\",\n        \"regex\": \"\",\n        \"statusCode\": 0\n      }\n    ],\n    \"rewrites\": [\n      {\n        \"dynamicLinks\": false,\n        \"function\": \"\",\n        \"functionRegion\": \"\",\n        \"glob\": \"\",\n        \"path\": \"\",\n        \"regex\": \"\",\n        \"run\": {\n          \"region\": \"\",\n          \"serviceId\": \"\"\n        }\n      }\n    ],\n    \"trailingSlashBehavior\": \"\"\n  },\n  \"createTime\": \"\",\n  \"createUser\": {\n    \"email\": \"\",\n    \"imageUrl\": \"\"\n  },\n  \"deleteTime\": \"\",\n  \"deleteUser\": {},\n  \"fileCount\": \"\",\n  \"finalizeTime\": \"\",\n  \"finalizeUser\": {},\n  \"labels\": {},\n  \"name\": \"\",\n  \"status\": \"\",\n  \"versionBytes\": \"\"\n}"
end

puts response.status
puts response.body
use std::str::FromStr;
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/:name";

    let payload = json!({
        "config": json!({
            "appAssociation": "",
            "cleanUrls": false,
            "headers": (
                json!({
                    "glob": "",
                    "headers": json!({}),
                    "regex": ""
                })
            ),
            "i18n": json!({"root": ""}),
            "redirects": (
                json!({
                    "glob": "",
                    "location": "",
                    "regex": "",
                    "statusCode": 0
                })
            ),
            "rewrites": (
                json!({
                    "dynamicLinks": false,
                    "function": "",
                    "functionRegion": "",
                    "glob": "",
                    "path": "",
                    "regex": "",
                    "run": json!({
                        "region": "",
                        "serviceId": ""
                    })
                })
            ),
            "trailingSlashBehavior": ""
        }),
        "createTime": "",
        "createUser": json!({
            "email": "",
            "imageUrl": ""
        }),
        "deleteTime": "",
        "deleteUser": json!({}),
        "fileCount": "",
        "finalizeTime": "",
        "finalizeUser": json!({}),
        "labels": json!({}),
        "name": "",
        "status": "",
        "versionBytes": ""
    });

    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}}/v1beta1/:name \
  --header 'content-type: application/json' \
  --data '{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}'
echo '{
  "config": {
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      {
        "glob": "",
        "headers": {},
        "regex": ""
      }
    ],
    "i18n": {
      "root": ""
    },
    "redirects": [
      {
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      }
    ],
    "rewrites": [
      {
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": {
          "region": "",
          "serviceId": ""
        }
      }
    ],
    "trailingSlashBehavior": ""
  },
  "createTime": "",
  "createUser": {
    "email": "",
    "imageUrl": ""
  },
  "deleteTime": "",
  "deleteUser": {},
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": {},
  "labels": {},
  "name": "",
  "status": "",
  "versionBytes": ""
}' |  \
  http PATCH {{baseUrl}}/v1beta1/:name \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'content-type: application/json' \
  --body-data '{\n  "config": {\n    "appAssociation": "",\n    "cleanUrls": false,\n    "headers": [\n      {\n        "glob": "",\n        "headers": {},\n        "regex": ""\n      }\n    ],\n    "i18n": {\n      "root": ""\n    },\n    "redirects": [\n      {\n        "glob": "",\n        "location": "",\n        "regex": "",\n        "statusCode": 0\n      }\n    ],\n    "rewrites": [\n      {\n        "dynamicLinks": false,\n        "function": "",\n        "functionRegion": "",\n        "glob": "",\n        "path": "",\n        "regex": "",\n        "run": {\n          "region": "",\n          "serviceId": ""\n        }\n      }\n    ],\n    "trailingSlashBehavior": ""\n  },\n  "createTime": "",\n  "createUser": {\n    "email": "",\n    "imageUrl": ""\n  },\n  "deleteTime": "",\n  "deleteUser": {},\n  "fileCount": "",\n  "finalizeTime": "",\n  "finalizeUser": {},\n  "labels": {},\n  "name": "",\n  "status": "",\n  "versionBytes": ""\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:name
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "config": [
    "appAssociation": "",
    "cleanUrls": false,
    "headers": [
      [
        "glob": "",
        "headers": [],
        "regex": ""
      ]
    ],
    "i18n": ["root": ""],
    "redirects": [
      [
        "glob": "",
        "location": "",
        "regex": "",
        "statusCode": 0
      ]
    ],
    "rewrites": [
      [
        "dynamicLinks": false,
        "function": "",
        "functionRegion": "",
        "glob": "",
        "path": "",
        "regex": "",
        "run": [
          "region": "",
          "serviceId": ""
        ]
      ]
    ],
    "trailingSlashBehavior": ""
  ],
  "createTime": "",
  "createUser": [
    "email": "",
    "imageUrl": ""
  ],
  "deleteTime": "",
  "deleteUser": [],
  "fileCount": "",
  "finalizeTime": "",
  "finalizeUser": [],
  "labels": [],
  "name": "",
  "status": "",
  "versionBytes": ""
] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:name")! as URL,
                                        cachePolicy: .useProtocolCachePolicy,
                                    timeoutInterval: 10.0)
request.httpMethod = "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 firebasehosting.sites.versions.populateFiles
{{baseUrl}}/v1beta1/:parent:populateFiles
QUERY PARAMS

parent
BODY json

{
  "files": {}
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "POST");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/v1beta1/:parent:populateFiles");

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  \"files\": {}\n}");

CURLcode ret = curl_easy_perform(hnd);
(require '[clj-http.client :as client])

(client/post "{{baseUrl}}/v1beta1/:parent:populateFiles" {:content-type :json
                                                                          :form-params {:files {}}})
require "http/client"

url = "{{baseUrl}}/v1beta1/:parent:populateFiles"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"files\": {}\n}"

response = HTTP::Client.post url, headers: headers, body: reqBody
puts response.body
using System.Net.Http.Headers;
var client = new HttpClient();
var request = new HttpRequestMessage
{
    Method = HttpMethod.Post,
    RequestUri = new Uri("{{baseUrl}}/v1beta1/:parent:populateFiles"),
    Content = new StringContent("{\n  \"files\": {}\n}")
    {
        Headers =
        {
            ContentType = new MediaTypeHeaderValue("application/json")
        }
    }
};
using (var response = await client.SendAsync(request))
{
    response.EnsureSuccessStatusCode();
    var body = await response.Content.ReadAsStringAsync();
    Console.WriteLine(body);
}
var client = new RestClient("{{baseUrl}}/v1beta1/:parent:populateFiles");
var request = new RestRequest("", Method.Post);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"files\": {}\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

import (
	"fmt"
	"strings"
	"net/http"
	"io"
)

func main() {

	url := "{{baseUrl}}/v1beta1/:parent:populateFiles"

	payload := strings.NewReader("{\n  \"files\": {}\n}")

	req, _ := http.NewRequest("POST", url, payload)

	req.Header.Add("content-type", "application/json")

	res, _ := http.DefaultClient.Do(req)

	defer res.Body.Close()
	body, _ := io.ReadAll(res.Body)

	fmt.Println(res)
	fmt.Println(string(body))

}
POST /baseUrl/v1beta1/:parent:populateFiles HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 17

{
  "files": {}
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("POST", "{{baseUrl}}/v1beta1/:parent:populateFiles")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"files\": {}\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/v1beta1/:parent:populateFiles"))
    .header("content-type", "application/json")
    .method("POST", HttpRequest.BodyPublishers.ofString("{\n  \"files\": {}\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  \"files\": {}\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent:populateFiles")
  .post(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.post("{{baseUrl}}/v1beta1/:parent:populateFiles")
  .header("content-type", "application/json")
  .body("{\n  \"files\": {}\n}")
  .asString();
const data = JSON.stringify({
  files: {}
});

const xhr = new XMLHttpRequest();
xhr.withCredentials = true;

xhr.addEventListener('readystatechange', function () {
  if (this.readyState === this.DONE) {
    console.log(this.responseText);
  }
});

xhr.open('POST', '{{baseUrl}}/v1beta1/:parent:populateFiles');
xhr.setRequestHeader('content-type', 'application/json');

xhr.send(data);
import axios from 'axios';

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent:populateFiles',
  headers: {'content-type': 'application/json'},
  data: {files: {}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/v1beta1/:parent:populateFiles';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"files":{}}'
};

try {
  const response = await fetch(url, options);
  const data = await response.json();
  console.log(data);
} catch (error) {
  console.error(error);
}
const settings = {
  async: true,
  crossDomain: true,
  url: '{{baseUrl}}/v1beta1/:parent:populateFiles',
  method: 'POST',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "files": {}\n}'
};

$.ajax(settings).done(function (response) {
  console.log(response);
});
val client = OkHttpClient()

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"files\": {}\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/v1beta1/:parent:populateFiles")
  .post(body)
  .addHeader("content-type", "application/json")
  .build()

val response = client.newCall(request).execute()
const http = require('https');

const options = {
  method: 'POST',
  hostname: 'example.com',
  port: null,
  path: '/baseUrl/v1beta1/:parent:populateFiles',
  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({files: {}}));
req.end();
const request = require('request');

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent:populateFiles',
  headers: {'content-type': 'application/json'},
  body: {files: {}},
  json: true
};

request(options, function (error, response, body) {
  if (error) throw new Error(error);

  console.log(body);
});
const unirest = require('unirest');

const req = unirest('POST', '{{baseUrl}}/v1beta1/:parent:populateFiles');

req.headers({
  'content-type': 'application/json'
});

req.type('json');
req.send({
  files: {}
});

req.end(function (res) {
  if (res.error) throw new Error(res.error);

  console.log(res.body);
});
const axios = require('axios').default;

const options = {
  method: 'POST',
  url: '{{baseUrl}}/v1beta1/:parent:populateFiles',
  headers: {'content-type': 'application/json'},
  data: {files: {}}
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const fetch = require('node-fetch');

const url = '{{baseUrl}}/v1beta1/:parent:populateFiles';
const options = {
  method: 'POST',
  headers: {'content-type': 'application/json'},
  body: '{"files":{}}'
};

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 = @{ @"files": @{  } };

NSData *postData = [NSJSONSerialization dataWithJSONObject:parameters options:0 error:nil];

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/v1beta1/:parent:populateFiles"]
                                                       cachePolicy:NSURLRequestUseProtocolCachePolicy
                                                   timeoutInterval:10.0];
[request setHTTPMethod:@"POST"];
[request setAllHTTPHeaderFields:headers];
[request setHTTPBody:postData];

NSURLSession *session = [NSURLSession sharedSession];
NSURLSessionDataTask *dataTask = [session dataTaskWithRequest:request
                                            completionHandler:^(NSData *data, NSURLResponse *response, NSError *error) {
                                                if (error) {
                                                    NSLog(@"%@", error);
                                                } else {
                                                    NSHTTPURLResponse *httpResponse = (NSHTTPURLResponse *) response;
                                                    NSLog(@"%@", httpResponse);
                                                }
                                            }];
[dataTask resume];
open Cohttp_lwt_unix
open Cohttp
open Lwt

let uri = Uri.of_string "{{baseUrl}}/v1beta1/:parent:populateFiles" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"files\": {}\n}" in

Client.call ~headers ~body `POST uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/v1beta1/:parent:populateFiles",
  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([
    'files' => [
        
    ]
  ]),
  CURLOPT_HTTPHEADER => [
    "content-type: application/json"
  ],
]);

$response = curl_exec($curl);
$err = curl_error($curl);

curl_close($curl);

if ($err) {
  echo "cURL Error #:" . $err;
} else {
  echo $response;
}
request('POST', '{{baseUrl}}/v1beta1/:parent:populateFiles', [
  'body' => '{
  "files": {}
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

echo $response->getBody();
setUrl('{{baseUrl}}/v1beta1/:parent:populateFiles');
$request->setMethod(HTTP_METH_POST);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$request->setContentType('application/json');
$request->setBody(json_encode([
  'files' => [
    
  ]
]));

try {
  $response = $request->send();

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'files' => [
    
  ]
]));
$request->setRequestUrl('{{baseUrl}}/v1beta1/:parent:populateFiles');
$request->setRequestMethod('POST');
$request->setBody($body);

$request->setHeaders([
  'content-type' => 'application/json'
]);

$client->enqueue($request)->send();
$response = $client->getResponse();

echo $response->getBody();
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-WebRequest -Uri '{{baseUrl}}/v1beta1/:parent:populateFiles' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "files": {}
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/v1beta1/:parent:populateFiles' -Method POST -Headers $headers -ContentType 'application/json' -Body '{
  "files": {}
}'
import http.client

conn = http.client.HTTPSConnection("example.com")

payload = "{\n  \"files\": {}\n}"

headers = { 'content-type': "application/json" }

conn.request("POST", "/baseUrl/v1beta1/:parent:populateFiles", payload, headers)

res = conn.getresponse()
data = res.read()

print(data.decode("utf-8"))
import requests

url = "{{baseUrl}}/v1beta1/:parent:populateFiles"

payload = { "files": {} }
headers = {"content-type": "application/json"}

response = requests.post(url, json=payload, headers=headers)

print(response.json())
library(httr)

url <- "{{baseUrl}}/v1beta1/:parent:populateFiles"

payload <- "{\n  \"files\": {}\n}"

encode <- "json"

response <- VERB("POST", url, body = payload, content_type("application/json"), encode = encode)

content(response, "text")
require 'uri'
require 'net/http'

url = URI("{{baseUrl}}/v1beta1/:parent:populateFiles")

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  \"files\": {}\n}"

response = http.request(request)
puts response.read_body
require 'faraday'

conn = Faraday.new(
  url: 'https://example.com',
  headers: {'Content-Type' => 'application/json'}
)

response = conn.post('/baseUrl/v1beta1/:parent:populateFiles') do |req|
  req.body = "{\n  \"files\": {}\n}"
end

puts response.status
puts response.body
use serde_json::json;
use reqwest;

#[tokio::main]
pub async fn main() {
    let url = "{{baseUrl}}/v1beta1/:parent:populateFiles";

    let payload = json!({"files": json!({})});

    let mut headers = reqwest::header::HeaderMap::new();
    headers.insert("content-type", "application/json".parse().unwrap());

    let client = reqwest::Client::new();
    let response = client.post(url)
        .headers(headers)
        .json(&payload)
        .send()
        .await;

    let results = response.unwrap()
        .json::()
        .await
        .unwrap();

    dbg!(results);
}
curl --request POST \
  --url {{baseUrl}}/v1beta1/:parent:populateFiles \
  --header 'content-type: application/json' \
  --data '{
  "files": {}
}'
echo '{
  "files": {}
}' |  \
  http POST {{baseUrl}}/v1beta1/:parent:populateFiles \
  content-type:application/json
wget --quiet \
  --method POST \
  --header 'content-type: application/json' \
  --body-data '{\n  "files": {}\n}' \
  --output-document \
  - {{baseUrl}}/v1beta1/:parent:populateFiles
import Foundation

let headers = ["content-type": "application/json"]
let parameters = ["files": []] as [String : Any]

let postData = JSONSerialization.data(withJSONObject: parameters, options: [])

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/v1beta1/:parent:populateFiles")! 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()