GET groupsSettings.groups.get
{{baseUrl}}/:groupUniqueId
QUERY PARAMS

groupUniqueId
Examples
REQUEST

CURL *hnd = curl_easy_init();

curl_easy_setopt(hnd, CURLOPT_CUSTOMREQUEST, "GET");
curl_easy_setopt(hnd, CURLOPT_URL, "{{baseUrl}}/:groupUniqueId");

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

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

url = "{{baseUrl}}/:groupUniqueId"

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

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

func main() {

	url := "{{baseUrl}}/:groupUniqueId"

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

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

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

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

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

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

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

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

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

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

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

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

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

const req = unirest('GET', '{{baseUrl}}/:groupUniqueId');

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}}/:groupUniqueId'};

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

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

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

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

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

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

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

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

conn.request("GET", "/baseUrl/:groupUniqueId")

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

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

url = "{{baseUrl}}/:groupUniqueId"

response = requests.get(url)

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

url <- "{{baseUrl}}/:groupUniqueId"

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

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

url = URI("{{baseUrl}}/:groupUniqueId")

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/:groupUniqueId') do |req|
end

puts response.status
puts response.body
use reqwest;

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

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

let request = NSMutableURLRequest(url: NSURL(string: "{{baseUrl}}/:groupUniqueId")! 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 groupsSettings.groups.patch
{{baseUrl}}/:groupUniqueId
QUERY PARAMS

groupUniqueId
BODY json

{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}");

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

(client/patch "{{baseUrl}}/:groupUniqueId" {:content-type :json
                                                            :form-params {:allowExternalMembers ""
                                                                          :allowGoogleCommunication ""
                                                                          :allowWebPosting ""
                                                                          :archiveOnly ""
                                                                          :customFooterText ""
                                                                          :customReplyTo ""
                                                                          :customRolesEnabledForSettingsToBeMerged ""
                                                                          :defaultMessageDenyNotificationText ""
                                                                          :default_sender ""
                                                                          :description ""
                                                                          :email ""
                                                                          :enableCollaborativeInbox ""
                                                                          :favoriteRepliesOnTop ""
                                                                          :includeCustomFooter ""
                                                                          :includeInGlobalAddressList ""
                                                                          :isArchived ""
                                                                          :kind ""
                                                                          :maxMessageBytes 0
                                                                          :membersCanPostAsTheGroup ""
                                                                          :messageDisplayFont ""
                                                                          :messageModerationLevel ""
                                                                          :name ""
                                                                          :primaryLanguage ""
                                                                          :replyTo ""
                                                                          :sendMessageDenyNotification ""
                                                                          :showInGroupDirectory ""
                                                                          :spamModerationLevel ""
                                                                          :whoCanAdd ""
                                                                          :whoCanAddReferences ""
                                                                          :whoCanApproveMembers ""
                                                                          :whoCanApproveMessages ""
                                                                          :whoCanAssignTopics ""
                                                                          :whoCanAssistContent ""
                                                                          :whoCanBanUsers ""
                                                                          :whoCanContactOwner ""
                                                                          :whoCanDeleteAnyPost ""
                                                                          :whoCanDeleteTopics ""
                                                                          :whoCanDiscoverGroup ""
                                                                          :whoCanEnterFreeFormTags ""
                                                                          :whoCanHideAbuse ""
                                                                          :whoCanInvite ""
                                                                          :whoCanJoin ""
                                                                          :whoCanLeaveGroup ""
                                                                          :whoCanLockTopics ""
                                                                          :whoCanMakeTopicsSticky ""
                                                                          :whoCanMarkDuplicate ""
                                                                          :whoCanMarkFavoriteReplyOnAnyTopic ""
                                                                          :whoCanMarkFavoriteReplyOnOwnTopic ""
                                                                          :whoCanMarkNoResponseNeeded ""
                                                                          :whoCanModerateContent ""
                                                                          :whoCanModerateMembers ""
                                                                          :whoCanModifyMembers ""
                                                                          :whoCanModifyTagsAndCategories ""
                                                                          :whoCanMoveTopicsIn ""
                                                                          :whoCanMoveTopicsOut ""
                                                                          :whoCanPostAnnouncements ""
                                                                          :whoCanPostMessage ""
                                                                          :whoCanTakeTopics ""
                                                                          :whoCanUnassignTopic ""
                                                                          :whoCanUnmarkFavoriteReplyOnAnyTopic ""
                                                                          :whoCanViewGroup ""
                                                                          :whoCanViewMembership ""}})
require "http/client"

url = "{{baseUrl}}/:groupUniqueId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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}}/:groupUniqueId"),
    Content = new StringContent("{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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}}/:groupUniqueId");
var request = new RestRequest("", Method.Patch);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/:groupUniqueId"

	payload := strings.NewReader("{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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/:groupUniqueId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1788

{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PATCH", "{{baseUrl}}/:groupUniqueId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/:groupUniqueId"))
    .header("content-type", "application/json")
    .method("PATCH", HttpRequest.BodyPublishers.ofString("{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/:groupUniqueId")
  .patch(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.patch("{{baseUrl}}/:groupUniqueId")
  .header("content-type", "application/json")
  .body("{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  allowExternalMembers: '',
  allowGoogleCommunication: '',
  allowWebPosting: '',
  archiveOnly: '',
  customFooterText: '',
  customReplyTo: '',
  customRolesEnabledForSettingsToBeMerged: '',
  defaultMessageDenyNotificationText: '',
  default_sender: '',
  description: '',
  email: '',
  enableCollaborativeInbox: '',
  favoriteRepliesOnTop: '',
  includeCustomFooter: '',
  includeInGlobalAddressList: '',
  isArchived: '',
  kind: '',
  maxMessageBytes: 0,
  membersCanPostAsTheGroup: '',
  messageDisplayFont: '',
  messageModerationLevel: '',
  name: '',
  primaryLanguage: '',
  replyTo: '',
  sendMessageDenyNotification: '',
  showInGroupDirectory: '',
  spamModerationLevel: '',
  whoCanAdd: '',
  whoCanAddReferences: '',
  whoCanApproveMembers: '',
  whoCanApproveMessages: '',
  whoCanAssignTopics: '',
  whoCanAssistContent: '',
  whoCanBanUsers: '',
  whoCanContactOwner: '',
  whoCanDeleteAnyPost: '',
  whoCanDeleteTopics: '',
  whoCanDiscoverGroup: '',
  whoCanEnterFreeFormTags: '',
  whoCanHideAbuse: '',
  whoCanInvite: '',
  whoCanJoin: '',
  whoCanLeaveGroup: '',
  whoCanLockTopics: '',
  whoCanMakeTopicsSticky: '',
  whoCanMarkDuplicate: '',
  whoCanMarkFavoriteReplyOnAnyTopic: '',
  whoCanMarkFavoriteReplyOnOwnTopic: '',
  whoCanMarkNoResponseNeeded: '',
  whoCanModerateContent: '',
  whoCanModerateMembers: '',
  whoCanModifyMembers: '',
  whoCanModifyTagsAndCategories: '',
  whoCanMoveTopicsIn: '',
  whoCanMoveTopicsOut: '',
  whoCanPostAnnouncements: '',
  whoCanPostMessage: '',
  whoCanTakeTopics: '',
  whoCanUnassignTopic: '',
  whoCanUnmarkFavoriteReplyOnAnyTopic: '',
  whoCanViewGroup: '',
  whoCanViewMembership: ''
});

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

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

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

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

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/:groupUniqueId',
  headers: {'content-type': 'application/json'},
  data: {
    allowExternalMembers: '',
    allowGoogleCommunication: '',
    allowWebPosting: '',
    archiveOnly: '',
    customFooterText: '',
    customReplyTo: '',
    customRolesEnabledForSettingsToBeMerged: '',
    defaultMessageDenyNotificationText: '',
    default_sender: '',
    description: '',
    email: '',
    enableCollaborativeInbox: '',
    favoriteRepliesOnTop: '',
    includeCustomFooter: '',
    includeInGlobalAddressList: '',
    isArchived: '',
    kind: '',
    maxMessageBytes: 0,
    membersCanPostAsTheGroup: '',
    messageDisplayFont: '',
    messageModerationLevel: '',
    name: '',
    primaryLanguage: '',
    replyTo: '',
    sendMessageDenyNotification: '',
    showInGroupDirectory: '',
    spamModerationLevel: '',
    whoCanAdd: '',
    whoCanAddReferences: '',
    whoCanApproveMembers: '',
    whoCanApproveMessages: '',
    whoCanAssignTopics: '',
    whoCanAssistContent: '',
    whoCanBanUsers: '',
    whoCanContactOwner: '',
    whoCanDeleteAnyPost: '',
    whoCanDeleteTopics: '',
    whoCanDiscoverGroup: '',
    whoCanEnterFreeFormTags: '',
    whoCanHideAbuse: '',
    whoCanInvite: '',
    whoCanJoin: '',
    whoCanLeaveGroup: '',
    whoCanLockTopics: '',
    whoCanMakeTopicsSticky: '',
    whoCanMarkDuplicate: '',
    whoCanMarkFavoriteReplyOnAnyTopic: '',
    whoCanMarkFavoriteReplyOnOwnTopic: '',
    whoCanMarkNoResponseNeeded: '',
    whoCanModerateContent: '',
    whoCanModerateMembers: '',
    whoCanModifyMembers: '',
    whoCanModifyTagsAndCategories: '',
    whoCanMoveTopicsIn: '',
    whoCanMoveTopicsOut: '',
    whoCanPostAnnouncements: '',
    whoCanPostMessage: '',
    whoCanTakeTopics: '',
    whoCanUnassignTopic: '',
    whoCanUnmarkFavoriteReplyOnAnyTopic: '',
    whoCanViewGroup: '',
    whoCanViewMembership: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/:groupUniqueId';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"allowExternalMembers":"","allowGoogleCommunication":"","allowWebPosting":"","archiveOnly":"","customFooterText":"","customReplyTo":"","customRolesEnabledForSettingsToBeMerged":"","defaultMessageDenyNotificationText":"","default_sender":"","description":"","email":"","enableCollaborativeInbox":"","favoriteRepliesOnTop":"","includeCustomFooter":"","includeInGlobalAddressList":"","isArchived":"","kind":"","maxMessageBytes":0,"membersCanPostAsTheGroup":"","messageDisplayFont":"","messageModerationLevel":"","name":"","primaryLanguage":"","replyTo":"","sendMessageDenyNotification":"","showInGroupDirectory":"","spamModerationLevel":"","whoCanAdd":"","whoCanAddReferences":"","whoCanApproveMembers":"","whoCanApproveMessages":"","whoCanAssignTopics":"","whoCanAssistContent":"","whoCanBanUsers":"","whoCanContactOwner":"","whoCanDeleteAnyPost":"","whoCanDeleteTopics":"","whoCanDiscoverGroup":"","whoCanEnterFreeFormTags":"","whoCanHideAbuse":"","whoCanInvite":"","whoCanJoin":"","whoCanLeaveGroup":"","whoCanLockTopics":"","whoCanMakeTopicsSticky":"","whoCanMarkDuplicate":"","whoCanMarkFavoriteReplyOnAnyTopic":"","whoCanMarkFavoriteReplyOnOwnTopic":"","whoCanMarkNoResponseNeeded":"","whoCanModerateContent":"","whoCanModerateMembers":"","whoCanModifyMembers":"","whoCanModifyTagsAndCategories":"","whoCanMoveTopicsIn":"","whoCanMoveTopicsOut":"","whoCanPostAnnouncements":"","whoCanPostMessage":"","whoCanTakeTopics":"","whoCanUnassignTopic":"","whoCanUnmarkFavoriteReplyOnAnyTopic":"","whoCanViewGroup":"","whoCanViewMembership":""}'
};

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}}/:groupUniqueId',
  method: 'PATCH',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "allowExternalMembers": "",\n  "allowGoogleCommunication": "",\n  "allowWebPosting": "",\n  "archiveOnly": "",\n  "customFooterText": "",\n  "customReplyTo": "",\n  "customRolesEnabledForSettingsToBeMerged": "",\n  "defaultMessageDenyNotificationText": "",\n  "default_sender": "",\n  "description": "",\n  "email": "",\n  "enableCollaborativeInbox": "",\n  "favoriteRepliesOnTop": "",\n  "includeCustomFooter": "",\n  "includeInGlobalAddressList": "",\n  "isArchived": "",\n  "kind": "",\n  "maxMessageBytes": 0,\n  "membersCanPostAsTheGroup": "",\n  "messageDisplayFont": "",\n  "messageModerationLevel": "",\n  "name": "",\n  "primaryLanguage": "",\n  "replyTo": "",\n  "sendMessageDenyNotification": "",\n  "showInGroupDirectory": "",\n  "spamModerationLevel": "",\n  "whoCanAdd": "",\n  "whoCanAddReferences": "",\n  "whoCanApproveMembers": "",\n  "whoCanApproveMessages": "",\n  "whoCanAssignTopics": "",\n  "whoCanAssistContent": "",\n  "whoCanBanUsers": "",\n  "whoCanContactOwner": "",\n  "whoCanDeleteAnyPost": "",\n  "whoCanDeleteTopics": "",\n  "whoCanDiscoverGroup": "",\n  "whoCanEnterFreeFormTags": "",\n  "whoCanHideAbuse": "",\n  "whoCanInvite": "",\n  "whoCanJoin": "",\n  "whoCanLeaveGroup": "",\n  "whoCanLockTopics": "",\n  "whoCanMakeTopicsSticky": "",\n  "whoCanMarkDuplicate": "",\n  "whoCanMarkFavoriteReplyOnAnyTopic": "",\n  "whoCanMarkFavoriteReplyOnOwnTopic": "",\n  "whoCanMarkNoResponseNeeded": "",\n  "whoCanModerateContent": "",\n  "whoCanModerateMembers": "",\n  "whoCanModifyMembers": "",\n  "whoCanModifyTagsAndCategories": "",\n  "whoCanMoveTopicsIn": "",\n  "whoCanMoveTopicsOut": "",\n  "whoCanPostAnnouncements": "",\n  "whoCanPostMessage": "",\n  "whoCanTakeTopics": "",\n  "whoCanUnassignTopic": "",\n  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",\n  "whoCanViewGroup": "",\n  "whoCanViewMembership": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/:groupUniqueId")
  .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/:groupUniqueId',
  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({
  allowExternalMembers: '',
  allowGoogleCommunication: '',
  allowWebPosting: '',
  archiveOnly: '',
  customFooterText: '',
  customReplyTo: '',
  customRolesEnabledForSettingsToBeMerged: '',
  defaultMessageDenyNotificationText: '',
  default_sender: '',
  description: '',
  email: '',
  enableCollaborativeInbox: '',
  favoriteRepliesOnTop: '',
  includeCustomFooter: '',
  includeInGlobalAddressList: '',
  isArchived: '',
  kind: '',
  maxMessageBytes: 0,
  membersCanPostAsTheGroup: '',
  messageDisplayFont: '',
  messageModerationLevel: '',
  name: '',
  primaryLanguage: '',
  replyTo: '',
  sendMessageDenyNotification: '',
  showInGroupDirectory: '',
  spamModerationLevel: '',
  whoCanAdd: '',
  whoCanAddReferences: '',
  whoCanApproveMembers: '',
  whoCanApproveMessages: '',
  whoCanAssignTopics: '',
  whoCanAssistContent: '',
  whoCanBanUsers: '',
  whoCanContactOwner: '',
  whoCanDeleteAnyPost: '',
  whoCanDeleteTopics: '',
  whoCanDiscoverGroup: '',
  whoCanEnterFreeFormTags: '',
  whoCanHideAbuse: '',
  whoCanInvite: '',
  whoCanJoin: '',
  whoCanLeaveGroup: '',
  whoCanLockTopics: '',
  whoCanMakeTopicsSticky: '',
  whoCanMarkDuplicate: '',
  whoCanMarkFavoriteReplyOnAnyTopic: '',
  whoCanMarkFavoriteReplyOnOwnTopic: '',
  whoCanMarkNoResponseNeeded: '',
  whoCanModerateContent: '',
  whoCanModerateMembers: '',
  whoCanModifyMembers: '',
  whoCanModifyTagsAndCategories: '',
  whoCanMoveTopicsIn: '',
  whoCanMoveTopicsOut: '',
  whoCanPostAnnouncements: '',
  whoCanPostMessage: '',
  whoCanTakeTopics: '',
  whoCanUnassignTopic: '',
  whoCanUnmarkFavoriteReplyOnAnyTopic: '',
  whoCanViewGroup: '',
  whoCanViewMembership: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PATCH',
  url: '{{baseUrl}}/:groupUniqueId',
  headers: {'content-type': 'application/json'},
  body: {
    allowExternalMembers: '',
    allowGoogleCommunication: '',
    allowWebPosting: '',
    archiveOnly: '',
    customFooterText: '',
    customReplyTo: '',
    customRolesEnabledForSettingsToBeMerged: '',
    defaultMessageDenyNotificationText: '',
    default_sender: '',
    description: '',
    email: '',
    enableCollaborativeInbox: '',
    favoriteRepliesOnTop: '',
    includeCustomFooter: '',
    includeInGlobalAddressList: '',
    isArchived: '',
    kind: '',
    maxMessageBytes: 0,
    membersCanPostAsTheGroup: '',
    messageDisplayFont: '',
    messageModerationLevel: '',
    name: '',
    primaryLanguage: '',
    replyTo: '',
    sendMessageDenyNotification: '',
    showInGroupDirectory: '',
    spamModerationLevel: '',
    whoCanAdd: '',
    whoCanAddReferences: '',
    whoCanApproveMembers: '',
    whoCanApproveMessages: '',
    whoCanAssignTopics: '',
    whoCanAssistContent: '',
    whoCanBanUsers: '',
    whoCanContactOwner: '',
    whoCanDeleteAnyPost: '',
    whoCanDeleteTopics: '',
    whoCanDiscoverGroup: '',
    whoCanEnterFreeFormTags: '',
    whoCanHideAbuse: '',
    whoCanInvite: '',
    whoCanJoin: '',
    whoCanLeaveGroup: '',
    whoCanLockTopics: '',
    whoCanMakeTopicsSticky: '',
    whoCanMarkDuplicate: '',
    whoCanMarkFavoriteReplyOnAnyTopic: '',
    whoCanMarkFavoriteReplyOnOwnTopic: '',
    whoCanMarkNoResponseNeeded: '',
    whoCanModerateContent: '',
    whoCanModerateMembers: '',
    whoCanModifyMembers: '',
    whoCanModifyTagsAndCategories: '',
    whoCanMoveTopicsIn: '',
    whoCanMoveTopicsOut: '',
    whoCanPostAnnouncements: '',
    whoCanPostMessage: '',
    whoCanTakeTopics: '',
    whoCanUnassignTopic: '',
    whoCanUnmarkFavoriteReplyOnAnyTopic: '',
    whoCanViewGroup: '',
    whoCanViewMembership: ''
  },
  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}}/:groupUniqueId');

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

req.type('json');
req.send({
  allowExternalMembers: '',
  allowGoogleCommunication: '',
  allowWebPosting: '',
  archiveOnly: '',
  customFooterText: '',
  customReplyTo: '',
  customRolesEnabledForSettingsToBeMerged: '',
  defaultMessageDenyNotificationText: '',
  default_sender: '',
  description: '',
  email: '',
  enableCollaborativeInbox: '',
  favoriteRepliesOnTop: '',
  includeCustomFooter: '',
  includeInGlobalAddressList: '',
  isArchived: '',
  kind: '',
  maxMessageBytes: 0,
  membersCanPostAsTheGroup: '',
  messageDisplayFont: '',
  messageModerationLevel: '',
  name: '',
  primaryLanguage: '',
  replyTo: '',
  sendMessageDenyNotification: '',
  showInGroupDirectory: '',
  spamModerationLevel: '',
  whoCanAdd: '',
  whoCanAddReferences: '',
  whoCanApproveMembers: '',
  whoCanApproveMessages: '',
  whoCanAssignTopics: '',
  whoCanAssistContent: '',
  whoCanBanUsers: '',
  whoCanContactOwner: '',
  whoCanDeleteAnyPost: '',
  whoCanDeleteTopics: '',
  whoCanDiscoverGroup: '',
  whoCanEnterFreeFormTags: '',
  whoCanHideAbuse: '',
  whoCanInvite: '',
  whoCanJoin: '',
  whoCanLeaveGroup: '',
  whoCanLockTopics: '',
  whoCanMakeTopicsSticky: '',
  whoCanMarkDuplicate: '',
  whoCanMarkFavoriteReplyOnAnyTopic: '',
  whoCanMarkFavoriteReplyOnOwnTopic: '',
  whoCanMarkNoResponseNeeded: '',
  whoCanModerateContent: '',
  whoCanModerateMembers: '',
  whoCanModifyMembers: '',
  whoCanModifyTagsAndCategories: '',
  whoCanMoveTopicsIn: '',
  whoCanMoveTopicsOut: '',
  whoCanPostAnnouncements: '',
  whoCanPostMessage: '',
  whoCanTakeTopics: '',
  whoCanUnassignTopic: '',
  whoCanUnmarkFavoriteReplyOnAnyTopic: '',
  whoCanViewGroup: '',
  whoCanViewMembership: ''
});

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}}/:groupUniqueId',
  headers: {'content-type': 'application/json'},
  data: {
    allowExternalMembers: '',
    allowGoogleCommunication: '',
    allowWebPosting: '',
    archiveOnly: '',
    customFooterText: '',
    customReplyTo: '',
    customRolesEnabledForSettingsToBeMerged: '',
    defaultMessageDenyNotificationText: '',
    default_sender: '',
    description: '',
    email: '',
    enableCollaborativeInbox: '',
    favoriteRepliesOnTop: '',
    includeCustomFooter: '',
    includeInGlobalAddressList: '',
    isArchived: '',
    kind: '',
    maxMessageBytes: 0,
    membersCanPostAsTheGroup: '',
    messageDisplayFont: '',
    messageModerationLevel: '',
    name: '',
    primaryLanguage: '',
    replyTo: '',
    sendMessageDenyNotification: '',
    showInGroupDirectory: '',
    spamModerationLevel: '',
    whoCanAdd: '',
    whoCanAddReferences: '',
    whoCanApproveMembers: '',
    whoCanApproveMessages: '',
    whoCanAssignTopics: '',
    whoCanAssistContent: '',
    whoCanBanUsers: '',
    whoCanContactOwner: '',
    whoCanDeleteAnyPost: '',
    whoCanDeleteTopics: '',
    whoCanDiscoverGroup: '',
    whoCanEnterFreeFormTags: '',
    whoCanHideAbuse: '',
    whoCanInvite: '',
    whoCanJoin: '',
    whoCanLeaveGroup: '',
    whoCanLockTopics: '',
    whoCanMakeTopicsSticky: '',
    whoCanMarkDuplicate: '',
    whoCanMarkFavoriteReplyOnAnyTopic: '',
    whoCanMarkFavoriteReplyOnOwnTopic: '',
    whoCanMarkNoResponseNeeded: '',
    whoCanModerateContent: '',
    whoCanModerateMembers: '',
    whoCanModifyMembers: '',
    whoCanModifyTagsAndCategories: '',
    whoCanMoveTopicsIn: '',
    whoCanMoveTopicsOut: '',
    whoCanPostAnnouncements: '',
    whoCanPostMessage: '',
    whoCanTakeTopics: '',
    whoCanUnassignTopic: '',
    whoCanUnmarkFavoriteReplyOnAnyTopic: '',
    whoCanViewGroup: '',
    whoCanViewMembership: ''
  }
};

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

const url = '{{baseUrl}}/:groupUniqueId';
const options = {
  method: 'PATCH',
  headers: {'content-type': 'application/json'},
  body: '{"allowExternalMembers":"","allowGoogleCommunication":"","allowWebPosting":"","archiveOnly":"","customFooterText":"","customReplyTo":"","customRolesEnabledForSettingsToBeMerged":"","defaultMessageDenyNotificationText":"","default_sender":"","description":"","email":"","enableCollaborativeInbox":"","favoriteRepliesOnTop":"","includeCustomFooter":"","includeInGlobalAddressList":"","isArchived":"","kind":"","maxMessageBytes":0,"membersCanPostAsTheGroup":"","messageDisplayFont":"","messageModerationLevel":"","name":"","primaryLanguage":"","replyTo":"","sendMessageDenyNotification":"","showInGroupDirectory":"","spamModerationLevel":"","whoCanAdd":"","whoCanAddReferences":"","whoCanApproveMembers":"","whoCanApproveMessages":"","whoCanAssignTopics":"","whoCanAssistContent":"","whoCanBanUsers":"","whoCanContactOwner":"","whoCanDeleteAnyPost":"","whoCanDeleteTopics":"","whoCanDiscoverGroup":"","whoCanEnterFreeFormTags":"","whoCanHideAbuse":"","whoCanInvite":"","whoCanJoin":"","whoCanLeaveGroup":"","whoCanLockTopics":"","whoCanMakeTopicsSticky":"","whoCanMarkDuplicate":"","whoCanMarkFavoriteReplyOnAnyTopic":"","whoCanMarkFavoriteReplyOnOwnTopic":"","whoCanMarkNoResponseNeeded":"","whoCanModerateContent":"","whoCanModerateMembers":"","whoCanModifyMembers":"","whoCanModifyTagsAndCategories":"","whoCanMoveTopicsIn":"","whoCanMoveTopicsOut":"","whoCanPostAnnouncements":"","whoCanPostMessage":"","whoCanTakeTopics":"","whoCanUnassignTopic":"","whoCanUnmarkFavoriteReplyOnAnyTopic":"","whoCanViewGroup":"","whoCanViewMembership":""}'
};

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 = @{ @"allowExternalMembers": @"",
                              @"allowGoogleCommunication": @"",
                              @"allowWebPosting": @"",
                              @"archiveOnly": @"",
                              @"customFooterText": @"",
                              @"customReplyTo": @"",
                              @"customRolesEnabledForSettingsToBeMerged": @"",
                              @"defaultMessageDenyNotificationText": @"",
                              @"default_sender": @"",
                              @"description": @"",
                              @"email": @"",
                              @"enableCollaborativeInbox": @"",
                              @"favoriteRepliesOnTop": @"",
                              @"includeCustomFooter": @"",
                              @"includeInGlobalAddressList": @"",
                              @"isArchived": @"",
                              @"kind": @"",
                              @"maxMessageBytes": @0,
                              @"membersCanPostAsTheGroup": @"",
                              @"messageDisplayFont": @"",
                              @"messageModerationLevel": @"",
                              @"name": @"",
                              @"primaryLanguage": @"",
                              @"replyTo": @"",
                              @"sendMessageDenyNotification": @"",
                              @"showInGroupDirectory": @"",
                              @"spamModerationLevel": @"",
                              @"whoCanAdd": @"",
                              @"whoCanAddReferences": @"",
                              @"whoCanApproveMembers": @"",
                              @"whoCanApproveMessages": @"",
                              @"whoCanAssignTopics": @"",
                              @"whoCanAssistContent": @"",
                              @"whoCanBanUsers": @"",
                              @"whoCanContactOwner": @"",
                              @"whoCanDeleteAnyPost": @"",
                              @"whoCanDeleteTopics": @"",
                              @"whoCanDiscoverGroup": @"",
                              @"whoCanEnterFreeFormTags": @"",
                              @"whoCanHideAbuse": @"",
                              @"whoCanInvite": @"",
                              @"whoCanJoin": @"",
                              @"whoCanLeaveGroup": @"",
                              @"whoCanLockTopics": @"",
                              @"whoCanMakeTopicsSticky": @"",
                              @"whoCanMarkDuplicate": @"",
                              @"whoCanMarkFavoriteReplyOnAnyTopic": @"",
                              @"whoCanMarkFavoriteReplyOnOwnTopic": @"",
                              @"whoCanMarkNoResponseNeeded": @"",
                              @"whoCanModerateContent": @"",
                              @"whoCanModerateMembers": @"",
                              @"whoCanModifyMembers": @"",
                              @"whoCanModifyTagsAndCategories": @"",
                              @"whoCanMoveTopicsIn": @"",
                              @"whoCanMoveTopicsOut": @"",
                              @"whoCanPostAnnouncements": @"",
                              @"whoCanPostMessage": @"",
                              @"whoCanTakeTopics": @"",
                              @"whoCanUnassignTopic": @"",
                              @"whoCanUnmarkFavoriteReplyOnAnyTopic": @"",
                              @"whoCanViewGroup": @"",
                              @"whoCanViewMembership": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/:groupUniqueId"]
                                                       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}}/:groupUniqueId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}" in

Client.call ~headers ~body `PATCH uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/:groupUniqueId",
  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([
    'allowExternalMembers' => '',
    'allowGoogleCommunication' => '',
    'allowWebPosting' => '',
    'archiveOnly' => '',
    'customFooterText' => '',
    'customReplyTo' => '',
    'customRolesEnabledForSettingsToBeMerged' => '',
    'defaultMessageDenyNotificationText' => '',
    'default_sender' => '',
    'description' => '',
    'email' => '',
    'enableCollaborativeInbox' => '',
    'favoriteRepliesOnTop' => '',
    'includeCustomFooter' => '',
    'includeInGlobalAddressList' => '',
    'isArchived' => '',
    'kind' => '',
    'maxMessageBytes' => 0,
    'membersCanPostAsTheGroup' => '',
    'messageDisplayFont' => '',
    'messageModerationLevel' => '',
    'name' => '',
    'primaryLanguage' => '',
    'replyTo' => '',
    'sendMessageDenyNotification' => '',
    'showInGroupDirectory' => '',
    'spamModerationLevel' => '',
    'whoCanAdd' => '',
    'whoCanAddReferences' => '',
    'whoCanApproveMembers' => '',
    'whoCanApproveMessages' => '',
    'whoCanAssignTopics' => '',
    'whoCanAssistContent' => '',
    'whoCanBanUsers' => '',
    'whoCanContactOwner' => '',
    'whoCanDeleteAnyPost' => '',
    'whoCanDeleteTopics' => '',
    'whoCanDiscoverGroup' => '',
    'whoCanEnterFreeFormTags' => '',
    'whoCanHideAbuse' => '',
    'whoCanInvite' => '',
    'whoCanJoin' => '',
    'whoCanLeaveGroup' => '',
    'whoCanLockTopics' => '',
    'whoCanMakeTopicsSticky' => '',
    'whoCanMarkDuplicate' => '',
    'whoCanMarkFavoriteReplyOnAnyTopic' => '',
    'whoCanMarkFavoriteReplyOnOwnTopic' => '',
    'whoCanMarkNoResponseNeeded' => '',
    'whoCanModerateContent' => '',
    'whoCanModerateMembers' => '',
    'whoCanModifyMembers' => '',
    'whoCanModifyTagsAndCategories' => '',
    'whoCanMoveTopicsIn' => '',
    'whoCanMoveTopicsOut' => '',
    'whoCanPostAnnouncements' => '',
    'whoCanPostMessage' => '',
    'whoCanTakeTopics' => '',
    'whoCanUnassignTopic' => '',
    'whoCanUnmarkFavoriteReplyOnAnyTopic' => '',
    'whoCanViewGroup' => '',
    'whoCanViewMembership' => ''
  ]),
  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}}/:groupUniqueId', [
  'body' => '{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'allowExternalMembers' => '',
  'allowGoogleCommunication' => '',
  'allowWebPosting' => '',
  'archiveOnly' => '',
  'customFooterText' => '',
  'customReplyTo' => '',
  'customRolesEnabledForSettingsToBeMerged' => '',
  'defaultMessageDenyNotificationText' => '',
  'default_sender' => '',
  'description' => '',
  'email' => '',
  'enableCollaborativeInbox' => '',
  'favoriteRepliesOnTop' => '',
  'includeCustomFooter' => '',
  'includeInGlobalAddressList' => '',
  'isArchived' => '',
  'kind' => '',
  'maxMessageBytes' => 0,
  'membersCanPostAsTheGroup' => '',
  'messageDisplayFont' => '',
  'messageModerationLevel' => '',
  'name' => '',
  'primaryLanguage' => '',
  'replyTo' => '',
  'sendMessageDenyNotification' => '',
  'showInGroupDirectory' => '',
  'spamModerationLevel' => '',
  'whoCanAdd' => '',
  'whoCanAddReferences' => '',
  'whoCanApproveMembers' => '',
  'whoCanApproveMessages' => '',
  'whoCanAssignTopics' => '',
  'whoCanAssistContent' => '',
  'whoCanBanUsers' => '',
  'whoCanContactOwner' => '',
  'whoCanDeleteAnyPost' => '',
  'whoCanDeleteTopics' => '',
  'whoCanDiscoverGroup' => '',
  'whoCanEnterFreeFormTags' => '',
  'whoCanHideAbuse' => '',
  'whoCanInvite' => '',
  'whoCanJoin' => '',
  'whoCanLeaveGroup' => '',
  'whoCanLockTopics' => '',
  'whoCanMakeTopicsSticky' => '',
  'whoCanMarkDuplicate' => '',
  'whoCanMarkFavoriteReplyOnAnyTopic' => '',
  'whoCanMarkFavoriteReplyOnOwnTopic' => '',
  'whoCanMarkNoResponseNeeded' => '',
  'whoCanModerateContent' => '',
  'whoCanModerateMembers' => '',
  'whoCanModifyMembers' => '',
  'whoCanModifyTagsAndCategories' => '',
  'whoCanMoveTopicsIn' => '',
  'whoCanMoveTopicsOut' => '',
  'whoCanPostAnnouncements' => '',
  'whoCanPostMessage' => '',
  'whoCanTakeTopics' => '',
  'whoCanUnassignTopic' => '',
  'whoCanUnmarkFavoriteReplyOnAnyTopic' => '',
  'whoCanViewGroup' => '',
  'whoCanViewMembership' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'allowExternalMembers' => '',
  'allowGoogleCommunication' => '',
  'allowWebPosting' => '',
  'archiveOnly' => '',
  'customFooterText' => '',
  'customReplyTo' => '',
  'customRolesEnabledForSettingsToBeMerged' => '',
  'defaultMessageDenyNotificationText' => '',
  'default_sender' => '',
  'description' => '',
  'email' => '',
  'enableCollaborativeInbox' => '',
  'favoriteRepliesOnTop' => '',
  'includeCustomFooter' => '',
  'includeInGlobalAddressList' => '',
  'isArchived' => '',
  'kind' => '',
  'maxMessageBytes' => 0,
  'membersCanPostAsTheGroup' => '',
  'messageDisplayFont' => '',
  'messageModerationLevel' => '',
  'name' => '',
  'primaryLanguage' => '',
  'replyTo' => '',
  'sendMessageDenyNotification' => '',
  'showInGroupDirectory' => '',
  'spamModerationLevel' => '',
  'whoCanAdd' => '',
  'whoCanAddReferences' => '',
  'whoCanApproveMembers' => '',
  'whoCanApproveMessages' => '',
  'whoCanAssignTopics' => '',
  'whoCanAssistContent' => '',
  'whoCanBanUsers' => '',
  'whoCanContactOwner' => '',
  'whoCanDeleteAnyPost' => '',
  'whoCanDeleteTopics' => '',
  'whoCanDiscoverGroup' => '',
  'whoCanEnterFreeFormTags' => '',
  'whoCanHideAbuse' => '',
  'whoCanInvite' => '',
  'whoCanJoin' => '',
  'whoCanLeaveGroup' => '',
  'whoCanLockTopics' => '',
  'whoCanMakeTopicsSticky' => '',
  'whoCanMarkDuplicate' => '',
  'whoCanMarkFavoriteReplyOnAnyTopic' => '',
  'whoCanMarkFavoriteReplyOnOwnTopic' => '',
  'whoCanMarkNoResponseNeeded' => '',
  'whoCanModerateContent' => '',
  'whoCanModerateMembers' => '',
  'whoCanModifyMembers' => '',
  'whoCanModifyTagsAndCategories' => '',
  'whoCanMoveTopicsIn' => '',
  'whoCanMoveTopicsOut' => '',
  'whoCanPostAnnouncements' => '',
  'whoCanPostMessage' => '',
  'whoCanTakeTopics' => '',
  'whoCanUnassignTopic' => '',
  'whoCanUnmarkFavoriteReplyOnAnyTopic' => '',
  'whoCanViewGroup' => '',
  'whoCanViewMembership' => ''
]));
$request->setRequestUrl('{{baseUrl}}/:groupUniqueId');
$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}}/:groupUniqueId' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/:groupUniqueId' -Method PATCH -Headers $headers -ContentType 'application/json' -Body '{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}'
import http.client

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

payload = "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}"

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

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

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

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

url = "{{baseUrl}}/:groupUniqueId"

payload = {
    "allowExternalMembers": "",
    "allowGoogleCommunication": "",
    "allowWebPosting": "",
    "archiveOnly": "",
    "customFooterText": "",
    "customReplyTo": "",
    "customRolesEnabledForSettingsToBeMerged": "",
    "defaultMessageDenyNotificationText": "",
    "default_sender": "",
    "description": "",
    "email": "",
    "enableCollaborativeInbox": "",
    "favoriteRepliesOnTop": "",
    "includeCustomFooter": "",
    "includeInGlobalAddressList": "",
    "isArchived": "",
    "kind": "",
    "maxMessageBytes": 0,
    "membersCanPostAsTheGroup": "",
    "messageDisplayFont": "",
    "messageModerationLevel": "",
    "name": "",
    "primaryLanguage": "",
    "replyTo": "",
    "sendMessageDenyNotification": "",
    "showInGroupDirectory": "",
    "spamModerationLevel": "",
    "whoCanAdd": "",
    "whoCanAddReferences": "",
    "whoCanApproveMembers": "",
    "whoCanApproveMessages": "",
    "whoCanAssignTopics": "",
    "whoCanAssistContent": "",
    "whoCanBanUsers": "",
    "whoCanContactOwner": "",
    "whoCanDeleteAnyPost": "",
    "whoCanDeleteTopics": "",
    "whoCanDiscoverGroup": "",
    "whoCanEnterFreeFormTags": "",
    "whoCanHideAbuse": "",
    "whoCanInvite": "",
    "whoCanJoin": "",
    "whoCanLeaveGroup": "",
    "whoCanLockTopics": "",
    "whoCanMakeTopicsSticky": "",
    "whoCanMarkDuplicate": "",
    "whoCanMarkFavoriteReplyOnAnyTopic": "",
    "whoCanMarkFavoriteReplyOnOwnTopic": "",
    "whoCanMarkNoResponseNeeded": "",
    "whoCanModerateContent": "",
    "whoCanModerateMembers": "",
    "whoCanModifyMembers": "",
    "whoCanModifyTagsAndCategories": "",
    "whoCanMoveTopicsIn": "",
    "whoCanMoveTopicsOut": "",
    "whoCanPostAnnouncements": "",
    "whoCanPostMessage": "",
    "whoCanTakeTopics": "",
    "whoCanUnassignTopic": "",
    "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
    "whoCanViewGroup": "",
    "whoCanViewMembership": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/:groupUniqueId"

payload <- "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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}}/:groupUniqueId")

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  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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/:groupUniqueId') do |req|
  req.body = "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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}}/:groupUniqueId";

    let payload = json!({
        "allowExternalMembers": "",
        "allowGoogleCommunication": "",
        "allowWebPosting": "",
        "archiveOnly": "",
        "customFooterText": "",
        "customReplyTo": "",
        "customRolesEnabledForSettingsToBeMerged": "",
        "defaultMessageDenyNotificationText": "",
        "default_sender": "",
        "description": "",
        "email": "",
        "enableCollaborativeInbox": "",
        "favoriteRepliesOnTop": "",
        "includeCustomFooter": "",
        "includeInGlobalAddressList": "",
        "isArchived": "",
        "kind": "",
        "maxMessageBytes": 0,
        "membersCanPostAsTheGroup": "",
        "messageDisplayFont": "",
        "messageModerationLevel": "",
        "name": "",
        "primaryLanguage": "",
        "replyTo": "",
        "sendMessageDenyNotification": "",
        "showInGroupDirectory": "",
        "spamModerationLevel": "",
        "whoCanAdd": "",
        "whoCanAddReferences": "",
        "whoCanApproveMembers": "",
        "whoCanApproveMessages": "",
        "whoCanAssignTopics": "",
        "whoCanAssistContent": "",
        "whoCanBanUsers": "",
        "whoCanContactOwner": "",
        "whoCanDeleteAnyPost": "",
        "whoCanDeleteTopics": "",
        "whoCanDiscoverGroup": "",
        "whoCanEnterFreeFormTags": "",
        "whoCanHideAbuse": "",
        "whoCanInvite": "",
        "whoCanJoin": "",
        "whoCanLeaveGroup": "",
        "whoCanLockTopics": "",
        "whoCanMakeTopicsSticky": "",
        "whoCanMarkDuplicate": "",
        "whoCanMarkFavoriteReplyOnAnyTopic": "",
        "whoCanMarkFavoriteReplyOnOwnTopic": "",
        "whoCanMarkNoResponseNeeded": "",
        "whoCanModerateContent": "",
        "whoCanModerateMembers": "",
        "whoCanModifyMembers": "",
        "whoCanModifyTagsAndCategories": "",
        "whoCanMoveTopicsIn": "",
        "whoCanMoveTopicsOut": "",
        "whoCanPostAnnouncements": "",
        "whoCanPostMessage": "",
        "whoCanTakeTopics": "",
        "whoCanUnassignTopic": "",
        "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
        "whoCanViewGroup": "",
        "whoCanViewMembership": ""
    });

    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}}/:groupUniqueId \
  --header 'content-type: application/json' \
  --data '{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}'
echo '{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}' |  \
  http PATCH {{baseUrl}}/:groupUniqueId \
  content-type:application/json
wget --quiet \
  --method PATCH \
  --header 'content-type: application/json' \
  --body-data '{\n  "allowExternalMembers": "",\n  "allowGoogleCommunication": "",\n  "allowWebPosting": "",\n  "archiveOnly": "",\n  "customFooterText": "",\n  "customReplyTo": "",\n  "customRolesEnabledForSettingsToBeMerged": "",\n  "defaultMessageDenyNotificationText": "",\n  "default_sender": "",\n  "description": "",\n  "email": "",\n  "enableCollaborativeInbox": "",\n  "favoriteRepliesOnTop": "",\n  "includeCustomFooter": "",\n  "includeInGlobalAddressList": "",\n  "isArchived": "",\n  "kind": "",\n  "maxMessageBytes": 0,\n  "membersCanPostAsTheGroup": "",\n  "messageDisplayFont": "",\n  "messageModerationLevel": "",\n  "name": "",\n  "primaryLanguage": "",\n  "replyTo": "",\n  "sendMessageDenyNotification": "",\n  "showInGroupDirectory": "",\n  "spamModerationLevel": "",\n  "whoCanAdd": "",\n  "whoCanAddReferences": "",\n  "whoCanApproveMembers": "",\n  "whoCanApproveMessages": "",\n  "whoCanAssignTopics": "",\n  "whoCanAssistContent": "",\n  "whoCanBanUsers": "",\n  "whoCanContactOwner": "",\n  "whoCanDeleteAnyPost": "",\n  "whoCanDeleteTopics": "",\n  "whoCanDiscoverGroup": "",\n  "whoCanEnterFreeFormTags": "",\n  "whoCanHideAbuse": "",\n  "whoCanInvite": "",\n  "whoCanJoin": "",\n  "whoCanLeaveGroup": "",\n  "whoCanLockTopics": "",\n  "whoCanMakeTopicsSticky": "",\n  "whoCanMarkDuplicate": "",\n  "whoCanMarkFavoriteReplyOnAnyTopic": "",\n  "whoCanMarkFavoriteReplyOnOwnTopic": "",\n  "whoCanMarkNoResponseNeeded": "",\n  "whoCanModerateContent": "",\n  "whoCanModerateMembers": "",\n  "whoCanModifyMembers": "",\n  "whoCanModifyTagsAndCategories": "",\n  "whoCanMoveTopicsIn": "",\n  "whoCanMoveTopicsOut": "",\n  "whoCanPostAnnouncements": "",\n  "whoCanPostMessage": "",\n  "whoCanTakeTopics": "",\n  "whoCanUnassignTopic": "",\n  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",\n  "whoCanViewGroup": "",\n  "whoCanViewMembership": ""\n}' \
  --output-document \
  - {{baseUrl}}/:groupUniqueId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
] as [String : Any]

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

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

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

dataTask.resume()
PUT groupsSettings.groups.update
{{baseUrl}}/:groupUniqueId
QUERY PARAMS

groupUniqueId
BODY json

{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}
Examples
REQUEST

CURL *hnd = curl_easy_init();

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

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  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}");

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

(client/put "{{baseUrl}}/:groupUniqueId" {:content-type :json
                                                          :form-params {:allowExternalMembers ""
                                                                        :allowGoogleCommunication ""
                                                                        :allowWebPosting ""
                                                                        :archiveOnly ""
                                                                        :customFooterText ""
                                                                        :customReplyTo ""
                                                                        :customRolesEnabledForSettingsToBeMerged ""
                                                                        :defaultMessageDenyNotificationText ""
                                                                        :default_sender ""
                                                                        :description ""
                                                                        :email ""
                                                                        :enableCollaborativeInbox ""
                                                                        :favoriteRepliesOnTop ""
                                                                        :includeCustomFooter ""
                                                                        :includeInGlobalAddressList ""
                                                                        :isArchived ""
                                                                        :kind ""
                                                                        :maxMessageBytes 0
                                                                        :membersCanPostAsTheGroup ""
                                                                        :messageDisplayFont ""
                                                                        :messageModerationLevel ""
                                                                        :name ""
                                                                        :primaryLanguage ""
                                                                        :replyTo ""
                                                                        :sendMessageDenyNotification ""
                                                                        :showInGroupDirectory ""
                                                                        :spamModerationLevel ""
                                                                        :whoCanAdd ""
                                                                        :whoCanAddReferences ""
                                                                        :whoCanApproveMembers ""
                                                                        :whoCanApproveMessages ""
                                                                        :whoCanAssignTopics ""
                                                                        :whoCanAssistContent ""
                                                                        :whoCanBanUsers ""
                                                                        :whoCanContactOwner ""
                                                                        :whoCanDeleteAnyPost ""
                                                                        :whoCanDeleteTopics ""
                                                                        :whoCanDiscoverGroup ""
                                                                        :whoCanEnterFreeFormTags ""
                                                                        :whoCanHideAbuse ""
                                                                        :whoCanInvite ""
                                                                        :whoCanJoin ""
                                                                        :whoCanLeaveGroup ""
                                                                        :whoCanLockTopics ""
                                                                        :whoCanMakeTopicsSticky ""
                                                                        :whoCanMarkDuplicate ""
                                                                        :whoCanMarkFavoriteReplyOnAnyTopic ""
                                                                        :whoCanMarkFavoriteReplyOnOwnTopic ""
                                                                        :whoCanMarkNoResponseNeeded ""
                                                                        :whoCanModerateContent ""
                                                                        :whoCanModerateMembers ""
                                                                        :whoCanModifyMembers ""
                                                                        :whoCanModifyTagsAndCategories ""
                                                                        :whoCanMoveTopicsIn ""
                                                                        :whoCanMoveTopicsOut ""
                                                                        :whoCanPostAnnouncements ""
                                                                        :whoCanPostMessage ""
                                                                        :whoCanTakeTopics ""
                                                                        :whoCanUnassignTopic ""
                                                                        :whoCanUnmarkFavoriteReplyOnAnyTopic ""
                                                                        :whoCanViewGroup ""
                                                                        :whoCanViewMembership ""}})
require "http/client"

url = "{{baseUrl}}/:groupUniqueId"
headers = HTTP::Headers{
  "content-type" => "application/json"
}
reqBody = "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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}}/:groupUniqueId"),
    Content = new StringContent("{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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}}/:groupUniqueId");
var request = new RestRequest("", Method.Put);
request.AddHeader("content-type", "application/json");
request.AddParameter("application/json", "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}", ParameterType.RequestBody);
var response = client.Execute(request);
package main

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

func main() {

	url := "{{baseUrl}}/:groupUniqueId"

	payload := strings.NewReader("{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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/:groupUniqueId HTTP/1.1
Content-Type: application/json
Host: example.com
Content-Length: 1788

{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}
AsyncHttpClient client = new DefaultAsyncHttpClient();
client.prepare("PUT", "{{baseUrl}}/:groupUniqueId")
  .setHeader("content-type", "application/json")
  .setBody("{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}")
  .execute()
  .toCompletableFuture()
  .thenAccept(System.out::println)
  .join();

client.close();
HttpRequest request = HttpRequest.newBuilder()
    .uri(URI.create("{{baseUrl}}/:groupUniqueId"))
    .header("content-type", "application/json")
    .method("PUT", HttpRequest.BodyPublishers.ofString("{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}");
Request request = new Request.Builder()
  .url("{{baseUrl}}/:groupUniqueId")
  .put(body)
  .addHeader("content-type", "application/json")
  .build();

Response response = client.newCall(request).execute();
HttpResponse response = Unirest.put("{{baseUrl}}/:groupUniqueId")
  .header("content-type", "application/json")
  .body("{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}")
  .asString();
const data = JSON.stringify({
  allowExternalMembers: '',
  allowGoogleCommunication: '',
  allowWebPosting: '',
  archiveOnly: '',
  customFooterText: '',
  customReplyTo: '',
  customRolesEnabledForSettingsToBeMerged: '',
  defaultMessageDenyNotificationText: '',
  default_sender: '',
  description: '',
  email: '',
  enableCollaborativeInbox: '',
  favoriteRepliesOnTop: '',
  includeCustomFooter: '',
  includeInGlobalAddressList: '',
  isArchived: '',
  kind: '',
  maxMessageBytes: 0,
  membersCanPostAsTheGroup: '',
  messageDisplayFont: '',
  messageModerationLevel: '',
  name: '',
  primaryLanguage: '',
  replyTo: '',
  sendMessageDenyNotification: '',
  showInGroupDirectory: '',
  spamModerationLevel: '',
  whoCanAdd: '',
  whoCanAddReferences: '',
  whoCanApproveMembers: '',
  whoCanApproveMessages: '',
  whoCanAssignTopics: '',
  whoCanAssistContent: '',
  whoCanBanUsers: '',
  whoCanContactOwner: '',
  whoCanDeleteAnyPost: '',
  whoCanDeleteTopics: '',
  whoCanDiscoverGroup: '',
  whoCanEnterFreeFormTags: '',
  whoCanHideAbuse: '',
  whoCanInvite: '',
  whoCanJoin: '',
  whoCanLeaveGroup: '',
  whoCanLockTopics: '',
  whoCanMakeTopicsSticky: '',
  whoCanMarkDuplicate: '',
  whoCanMarkFavoriteReplyOnAnyTopic: '',
  whoCanMarkFavoriteReplyOnOwnTopic: '',
  whoCanMarkNoResponseNeeded: '',
  whoCanModerateContent: '',
  whoCanModerateMembers: '',
  whoCanModifyMembers: '',
  whoCanModifyTagsAndCategories: '',
  whoCanMoveTopicsIn: '',
  whoCanMoveTopicsOut: '',
  whoCanPostAnnouncements: '',
  whoCanPostMessage: '',
  whoCanTakeTopics: '',
  whoCanUnassignTopic: '',
  whoCanUnmarkFavoriteReplyOnAnyTopic: '',
  whoCanViewGroup: '',
  whoCanViewMembership: ''
});

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

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

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

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

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/:groupUniqueId',
  headers: {'content-type': 'application/json'},
  data: {
    allowExternalMembers: '',
    allowGoogleCommunication: '',
    allowWebPosting: '',
    archiveOnly: '',
    customFooterText: '',
    customReplyTo: '',
    customRolesEnabledForSettingsToBeMerged: '',
    defaultMessageDenyNotificationText: '',
    default_sender: '',
    description: '',
    email: '',
    enableCollaborativeInbox: '',
    favoriteRepliesOnTop: '',
    includeCustomFooter: '',
    includeInGlobalAddressList: '',
    isArchived: '',
    kind: '',
    maxMessageBytes: 0,
    membersCanPostAsTheGroup: '',
    messageDisplayFont: '',
    messageModerationLevel: '',
    name: '',
    primaryLanguage: '',
    replyTo: '',
    sendMessageDenyNotification: '',
    showInGroupDirectory: '',
    spamModerationLevel: '',
    whoCanAdd: '',
    whoCanAddReferences: '',
    whoCanApproveMembers: '',
    whoCanApproveMessages: '',
    whoCanAssignTopics: '',
    whoCanAssistContent: '',
    whoCanBanUsers: '',
    whoCanContactOwner: '',
    whoCanDeleteAnyPost: '',
    whoCanDeleteTopics: '',
    whoCanDiscoverGroup: '',
    whoCanEnterFreeFormTags: '',
    whoCanHideAbuse: '',
    whoCanInvite: '',
    whoCanJoin: '',
    whoCanLeaveGroup: '',
    whoCanLockTopics: '',
    whoCanMakeTopicsSticky: '',
    whoCanMarkDuplicate: '',
    whoCanMarkFavoriteReplyOnAnyTopic: '',
    whoCanMarkFavoriteReplyOnOwnTopic: '',
    whoCanMarkNoResponseNeeded: '',
    whoCanModerateContent: '',
    whoCanModerateMembers: '',
    whoCanModifyMembers: '',
    whoCanModifyTagsAndCategories: '',
    whoCanMoveTopicsIn: '',
    whoCanMoveTopicsOut: '',
    whoCanPostAnnouncements: '',
    whoCanPostMessage: '',
    whoCanTakeTopics: '',
    whoCanUnassignTopic: '',
    whoCanUnmarkFavoriteReplyOnAnyTopic: '',
    whoCanViewGroup: '',
    whoCanViewMembership: ''
  }
};

try {
  const { data } = await axios.request(options);
  console.log(data);
} catch (error) {
  console.error(error);
}
const url = '{{baseUrl}}/:groupUniqueId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"allowExternalMembers":"","allowGoogleCommunication":"","allowWebPosting":"","archiveOnly":"","customFooterText":"","customReplyTo":"","customRolesEnabledForSettingsToBeMerged":"","defaultMessageDenyNotificationText":"","default_sender":"","description":"","email":"","enableCollaborativeInbox":"","favoriteRepliesOnTop":"","includeCustomFooter":"","includeInGlobalAddressList":"","isArchived":"","kind":"","maxMessageBytes":0,"membersCanPostAsTheGroup":"","messageDisplayFont":"","messageModerationLevel":"","name":"","primaryLanguage":"","replyTo":"","sendMessageDenyNotification":"","showInGroupDirectory":"","spamModerationLevel":"","whoCanAdd":"","whoCanAddReferences":"","whoCanApproveMembers":"","whoCanApproveMessages":"","whoCanAssignTopics":"","whoCanAssistContent":"","whoCanBanUsers":"","whoCanContactOwner":"","whoCanDeleteAnyPost":"","whoCanDeleteTopics":"","whoCanDiscoverGroup":"","whoCanEnterFreeFormTags":"","whoCanHideAbuse":"","whoCanInvite":"","whoCanJoin":"","whoCanLeaveGroup":"","whoCanLockTopics":"","whoCanMakeTopicsSticky":"","whoCanMarkDuplicate":"","whoCanMarkFavoriteReplyOnAnyTopic":"","whoCanMarkFavoriteReplyOnOwnTopic":"","whoCanMarkNoResponseNeeded":"","whoCanModerateContent":"","whoCanModerateMembers":"","whoCanModifyMembers":"","whoCanModifyTagsAndCategories":"","whoCanMoveTopicsIn":"","whoCanMoveTopicsOut":"","whoCanPostAnnouncements":"","whoCanPostMessage":"","whoCanTakeTopics":"","whoCanUnassignTopic":"","whoCanUnmarkFavoriteReplyOnAnyTopic":"","whoCanViewGroup":"","whoCanViewMembership":""}'
};

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}}/:groupUniqueId',
  method: 'PUT',
  headers: {
    'content-type': 'application/json'
  },
  processData: false,
  data: '{\n  "allowExternalMembers": "",\n  "allowGoogleCommunication": "",\n  "allowWebPosting": "",\n  "archiveOnly": "",\n  "customFooterText": "",\n  "customReplyTo": "",\n  "customRolesEnabledForSettingsToBeMerged": "",\n  "defaultMessageDenyNotificationText": "",\n  "default_sender": "",\n  "description": "",\n  "email": "",\n  "enableCollaborativeInbox": "",\n  "favoriteRepliesOnTop": "",\n  "includeCustomFooter": "",\n  "includeInGlobalAddressList": "",\n  "isArchived": "",\n  "kind": "",\n  "maxMessageBytes": 0,\n  "membersCanPostAsTheGroup": "",\n  "messageDisplayFont": "",\n  "messageModerationLevel": "",\n  "name": "",\n  "primaryLanguage": "",\n  "replyTo": "",\n  "sendMessageDenyNotification": "",\n  "showInGroupDirectory": "",\n  "spamModerationLevel": "",\n  "whoCanAdd": "",\n  "whoCanAddReferences": "",\n  "whoCanApproveMembers": "",\n  "whoCanApproveMessages": "",\n  "whoCanAssignTopics": "",\n  "whoCanAssistContent": "",\n  "whoCanBanUsers": "",\n  "whoCanContactOwner": "",\n  "whoCanDeleteAnyPost": "",\n  "whoCanDeleteTopics": "",\n  "whoCanDiscoverGroup": "",\n  "whoCanEnterFreeFormTags": "",\n  "whoCanHideAbuse": "",\n  "whoCanInvite": "",\n  "whoCanJoin": "",\n  "whoCanLeaveGroup": "",\n  "whoCanLockTopics": "",\n  "whoCanMakeTopicsSticky": "",\n  "whoCanMarkDuplicate": "",\n  "whoCanMarkFavoriteReplyOnAnyTopic": "",\n  "whoCanMarkFavoriteReplyOnOwnTopic": "",\n  "whoCanMarkNoResponseNeeded": "",\n  "whoCanModerateContent": "",\n  "whoCanModerateMembers": "",\n  "whoCanModifyMembers": "",\n  "whoCanModifyTagsAndCategories": "",\n  "whoCanMoveTopicsIn": "",\n  "whoCanMoveTopicsOut": "",\n  "whoCanPostAnnouncements": "",\n  "whoCanPostMessage": "",\n  "whoCanTakeTopics": "",\n  "whoCanUnassignTopic": "",\n  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",\n  "whoCanViewGroup": "",\n  "whoCanViewMembership": ""\n}'
};

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

val mediaType = MediaType.parse("application/json")
val body = RequestBody.create(mediaType, "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}")
val request = Request.Builder()
  .url("{{baseUrl}}/:groupUniqueId")
  .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/:groupUniqueId',
  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({
  allowExternalMembers: '',
  allowGoogleCommunication: '',
  allowWebPosting: '',
  archiveOnly: '',
  customFooterText: '',
  customReplyTo: '',
  customRolesEnabledForSettingsToBeMerged: '',
  defaultMessageDenyNotificationText: '',
  default_sender: '',
  description: '',
  email: '',
  enableCollaborativeInbox: '',
  favoriteRepliesOnTop: '',
  includeCustomFooter: '',
  includeInGlobalAddressList: '',
  isArchived: '',
  kind: '',
  maxMessageBytes: 0,
  membersCanPostAsTheGroup: '',
  messageDisplayFont: '',
  messageModerationLevel: '',
  name: '',
  primaryLanguage: '',
  replyTo: '',
  sendMessageDenyNotification: '',
  showInGroupDirectory: '',
  spamModerationLevel: '',
  whoCanAdd: '',
  whoCanAddReferences: '',
  whoCanApproveMembers: '',
  whoCanApproveMessages: '',
  whoCanAssignTopics: '',
  whoCanAssistContent: '',
  whoCanBanUsers: '',
  whoCanContactOwner: '',
  whoCanDeleteAnyPost: '',
  whoCanDeleteTopics: '',
  whoCanDiscoverGroup: '',
  whoCanEnterFreeFormTags: '',
  whoCanHideAbuse: '',
  whoCanInvite: '',
  whoCanJoin: '',
  whoCanLeaveGroup: '',
  whoCanLockTopics: '',
  whoCanMakeTopicsSticky: '',
  whoCanMarkDuplicate: '',
  whoCanMarkFavoriteReplyOnAnyTopic: '',
  whoCanMarkFavoriteReplyOnOwnTopic: '',
  whoCanMarkNoResponseNeeded: '',
  whoCanModerateContent: '',
  whoCanModerateMembers: '',
  whoCanModifyMembers: '',
  whoCanModifyTagsAndCategories: '',
  whoCanMoveTopicsIn: '',
  whoCanMoveTopicsOut: '',
  whoCanPostAnnouncements: '',
  whoCanPostMessage: '',
  whoCanTakeTopics: '',
  whoCanUnassignTopic: '',
  whoCanUnmarkFavoriteReplyOnAnyTopic: '',
  whoCanViewGroup: '',
  whoCanViewMembership: ''
}));
req.end();
const request = require('request');

const options = {
  method: 'PUT',
  url: '{{baseUrl}}/:groupUniqueId',
  headers: {'content-type': 'application/json'},
  body: {
    allowExternalMembers: '',
    allowGoogleCommunication: '',
    allowWebPosting: '',
    archiveOnly: '',
    customFooterText: '',
    customReplyTo: '',
    customRolesEnabledForSettingsToBeMerged: '',
    defaultMessageDenyNotificationText: '',
    default_sender: '',
    description: '',
    email: '',
    enableCollaborativeInbox: '',
    favoriteRepliesOnTop: '',
    includeCustomFooter: '',
    includeInGlobalAddressList: '',
    isArchived: '',
    kind: '',
    maxMessageBytes: 0,
    membersCanPostAsTheGroup: '',
    messageDisplayFont: '',
    messageModerationLevel: '',
    name: '',
    primaryLanguage: '',
    replyTo: '',
    sendMessageDenyNotification: '',
    showInGroupDirectory: '',
    spamModerationLevel: '',
    whoCanAdd: '',
    whoCanAddReferences: '',
    whoCanApproveMembers: '',
    whoCanApproveMessages: '',
    whoCanAssignTopics: '',
    whoCanAssistContent: '',
    whoCanBanUsers: '',
    whoCanContactOwner: '',
    whoCanDeleteAnyPost: '',
    whoCanDeleteTopics: '',
    whoCanDiscoverGroup: '',
    whoCanEnterFreeFormTags: '',
    whoCanHideAbuse: '',
    whoCanInvite: '',
    whoCanJoin: '',
    whoCanLeaveGroup: '',
    whoCanLockTopics: '',
    whoCanMakeTopicsSticky: '',
    whoCanMarkDuplicate: '',
    whoCanMarkFavoriteReplyOnAnyTopic: '',
    whoCanMarkFavoriteReplyOnOwnTopic: '',
    whoCanMarkNoResponseNeeded: '',
    whoCanModerateContent: '',
    whoCanModerateMembers: '',
    whoCanModifyMembers: '',
    whoCanModifyTagsAndCategories: '',
    whoCanMoveTopicsIn: '',
    whoCanMoveTopicsOut: '',
    whoCanPostAnnouncements: '',
    whoCanPostMessage: '',
    whoCanTakeTopics: '',
    whoCanUnassignTopic: '',
    whoCanUnmarkFavoriteReplyOnAnyTopic: '',
    whoCanViewGroup: '',
    whoCanViewMembership: ''
  },
  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}}/:groupUniqueId');

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

req.type('json');
req.send({
  allowExternalMembers: '',
  allowGoogleCommunication: '',
  allowWebPosting: '',
  archiveOnly: '',
  customFooterText: '',
  customReplyTo: '',
  customRolesEnabledForSettingsToBeMerged: '',
  defaultMessageDenyNotificationText: '',
  default_sender: '',
  description: '',
  email: '',
  enableCollaborativeInbox: '',
  favoriteRepliesOnTop: '',
  includeCustomFooter: '',
  includeInGlobalAddressList: '',
  isArchived: '',
  kind: '',
  maxMessageBytes: 0,
  membersCanPostAsTheGroup: '',
  messageDisplayFont: '',
  messageModerationLevel: '',
  name: '',
  primaryLanguage: '',
  replyTo: '',
  sendMessageDenyNotification: '',
  showInGroupDirectory: '',
  spamModerationLevel: '',
  whoCanAdd: '',
  whoCanAddReferences: '',
  whoCanApproveMembers: '',
  whoCanApproveMessages: '',
  whoCanAssignTopics: '',
  whoCanAssistContent: '',
  whoCanBanUsers: '',
  whoCanContactOwner: '',
  whoCanDeleteAnyPost: '',
  whoCanDeleteTopics: '',
  whoCanDiscoverGroup: '',
  whoCanEnterFreeFormTags: '',
  whoCanHideAbuse: '',
  whoCanInvite: '',
  whoCanJoin: '',
  whoCanLeaveGroup: '',
  whoCanLockTopics: '',
  whoCanMakeTopicsSticky: '',
  whoCanMarkDuplicate: '',
  whoCanMarkFavoriteReplyOnAnyTopic: '',
  whoCanMarkFavoriteReplyOnOwnTopic: '',
  whoCanMarkNoResponseNeeded: '',
  whoCanModerateContent: '',
  whoCanModerateMembers: '',
  whoCanModifyMembers: '',
  whoCanModifyTagsAndCategories: '',
  whoCanMoveTopicsIn: '',
  whoCanMoveTopicsOut: '',
  whoCanPostAnnouncements: '',
  whoCanPostMessage: '',
  whoCanTakeTopics: '',
  whoCanUnassignTopic: '',
  whoCanUnmarkFavoriteReplyOnAnyTopic: '',
  whoCanViewGroup: '',
  whoCanViewMembership: ''
});

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}}/:groupUniqueId',
  headers: {'content-type': 'application/json'},
  data: {
    allowExternalMembers: '',
    allowGoogleCommunication: '',
    allowWebPosting: '',
    archiveOnly: '',
    customFooterText: '',
    customReplyTo: '',
    customRolesEnabledForSettingsToBeMerged: '',
    defaultMessageDenyNotificationText: '',
    default_sender: '',
    description: '',
    email: '',
    enableCollaborativeInbox: '',
    favoriteRepliesOnTop: '',
    includeCustomFooter: '',
    includeInGlobalAddressList: '',
    isArchived: '',
    kind: '',
    maxMessageBytes: 0,
    membersCanPostAsTheGroup: '',
    messageDisplayFont: '',
    messageModerationLevel: '',
    name: '',
    primaryLanguage: '',
    replyTo: '',
    sendMessageDenyNotification: '',
    showInGroupDirectory: '',
    spamModerationLevel: '',
    whoCanAdd: '',
    whoCanAddReferences: '',
    whoCanApproveMembers: '',
    whoCanApproveMessages: '',
    whoCanAssignTopics: '',
    whoCanAssistContent: '',
    whoCanBanUsers: '',
    whoCanContactOwner: '',
    whoCanDeleteAnyPost: '',
    whoCanDeleteTopics: '',
    whoCanDiscoverGroup: '',
    whoCanEnterFreeFormTags: '',
    whoCanHideAbuse: '',
    whoCanInvite: '',
    whoCanJoin: '',
    whoCanLeaveGroup: '',
    whoCanLockTopics: '',
    whoCanMakeTopicsSticky: '',
    whoCanMarkDuplicate: '',
    whoCanMarkFavoriteReplyOnAnyTopic: '',
    whoCanMarkFavoriteReplyOnOwnTopic: '',
    whoCanMarkNoResponseNeeded: '',
    whoCanModerateContent: '',
    whoCanModerateMembers: '',
    whoCanModifyMembers: '',
    whoCanModifyTagsAndCategories: '',
    whoCanMoveTopicsIn: '',
    whoCanMoveTopicsOut: '',
    whoCanPostAnnouncements: '',
    whoCanPostMessage: '',
    whoCanTakeTopics: '',
    whoCanUnassignTopic: '',
    whoCanUnmarkFavoriteReplyOnAnyTopic: '',
    whoCanViewGroup: '',
    whoCanViewMembership: ''
  }
};

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

const url = '{{baseUrl}}/:groupUniqueId';
const options = {
  method: 'PUT',
  headers: {'content-type': 'application/json'},
  body: '{"allowExternalMembers":"","allowGoogleCommunication":"","allowWebPosting":"","archiveOnly":"","customFooterText":"","customReplyTo":"","customRolesEnabledForSettingsToBeMerged":"","defaultMessageDenyNotificationText":"","default_sender":"","description":"","email":"","enableCollaborativeInbox":"","favoriteRepliesOnTop":"","includeCustomFooter":"","includeInGlobalAddressList":"","isArchived":"","kind":"","maxMessageBytes":0,"membersCanPostAsTheGroup":"","messageDisplayFont":"","messageModerationLevel":"","name":"","primaryLanguage":"","replyTo":"","sendMessageDenyNotification":"","showInGroupDirectory":"","spamModerationLevel":"","whoCanAdd":"","whoCanAddReferences":"","whoCanApproveMembers":"","whoCanApproveMessages":"","whoCanAssignTopics":"","whoCanAssistContent":"","whoCanBanUsers":"","whoCanContactOwner":"","whoCanDeleteAnyPost":"","whoCanDeleteTopics":"","whoCanDiscoverGroup":"","whoCanEnterFreeFormTags":"","whoCanHideAbuse":"","whoCanInvite":"","whoCanJoin":"","whoCanLeaveGroup":"","whoCanLockTopics":"","whoCanMakeTopicsSticky":"","whoCanMarkDuplicate":"","whoCanMarkFavoriteReplyOnAnyTopic":"","whoCanMarkFavoriteReplyOnOwnTopic":"","whoCanMarkNoResponseNeeded":"","whoCanModerateContent":"","whoCanModerateMembers":"","whoCanModifyMembers":"","whoCanModifyTagsAndCategories":"","whoCanMoveTopicsIn":"","whoCanMoveTopicsOut":"","whoCanPostAnnouncements":"","whoCanPostMessage":"","whoCanTakeTopics":"","whoCanUnassignTopic":"","whoCanUnmarkFavoriteReplyOnAnyTopic":"","whoCanViewGroup":"","whoCanViewMembership":""}'
};

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 = @{ @"allowExternalMembers": @"",
                              @"allowGoogleCommunication": @"",
                              @"allowWebPosting": @"",
                              @"archiveOnly": @"",
                              @"customFooterText": @"",
                              @"customReplyTo": @"",
                              @"customRolesEnabledForSettingsToBeMerged": @"",
                              @"defaultMessageDenyNotificationText": @"",
                              @"default_sender": @"",
                              @"description": @"",
                              @"email": @"",
                              @"enableCollaborativeInbox": @"",
                              @"favoriteRepliesOnTop": @"",
                              @"includeCustomFooter": @"",
                              @"includeInGlobalAddressList": @"",
                              @"isArchived": @"",
                              @"kind": @"",
                              @"maxMessageBytes": @0,
                              @"membersCanPostAsTheGroup": @"",
                              @"messageDisplayFont": @"",
                              @"messageModerationLevel": @"",
                              @"name": @"",
                              @"primaryLanguage": @"",
                              @"replyTo": @"",
                              @"sendMessageDenyNotification": @"",
                              @"showInGroupDirectory": @"",
                              @"spamModerationLevel": @"",
                              @"whoCanAdd": @"",
                              @"whoCanAddReferences": @"",
                              @"whoCanApproveMembers": @"",
                              @"whoCanApproveMessages": @"",
                              @"whoCanAssignTopics": @"",
                              @"whoCanAssistContent": @"",
                              @"whoCanBanUsers": @"",
                              @"whoCanContactOwner": @"",
                              @"whoCanDeleteAnyPost": @"",
                              @"whoCanDeleteTopics": @"",
                              @"whoCanDiscoverGroup": @"",
                              @"whoCanEnterFreeFormTags": @"",
                              @"whoCanHideAbuse": @"",
                              @"whoCanInvite": @"",
                              @"whoCanJoin": @"",
                              @"whoCanLeaveGroup": @"",
                              @"whoCanLockTopics": @"",
                              @"whoCanMakeTopicsSticky": @"",
                              @"whoCanMarkDuplicate": @"",
                              @"whoCanMarkFavoriteReplyOnAnyTopic": @"",
                              @"whoCanMarkFavoriteReplyOnOwnTopic": @"",
                              @"whoCanMarkNoResponseNeeded": @"",
                              @"whoCanModerateContent": @"",
                              @"whoCanModerateMembers": @"",
                              @"whoCanModifyMembers": @"",
                              @"whoCanModifyTagsAndCategories": @"",
                              @"whoCanMoveTopicsIn": @"",
                              @"whoCanMoveTopicsOut": @"",
                              @"whoCanPostAnnouncements": @"",
                              @"whoCanPostMessage": @"",
                              @"whoCanTakeTopics": @"",
                              @"whoCanUnassignTopic": @"",
                              @"whoCanUnmarkFavoriteReplyOnAnyTopic": @"",
                              @"whoCanViewGroup": @"",
                              @"whoCanViewMembership": @"" };

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

NSMutableURLRequest *request = [NSMutableURLRequest requestWithURL:[NSURL URLWithString:@"{{baseUrl}}/:groupUniqueId"]
                                                       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}}/:groupUniqueId" in
let headers = Header.add (Header.init ()) "content-type" "application/json" in
let body = Cohttp_lwt_body.of_string "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}" in

Client.call ~headers ~body `PUT uri
>>= fun (res, body_stream) ->
  (* Do stuff with the result *)
 "{{baseUrl}}/:groupUniqueId",
  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([
    'allowExternalMembers' => '',
    'allowGoogleCommunication' => '',
    'allowWebPosting' => '',
    'archiveOnly' => '',
    'customFooterText' => '',
    'customReplyTo' => '',
    'customRolesEnabledForSettingsToBeMerged' => '',
    'defaultMessageDenyNotificationText' => '',
    'default_sender' => '',
    'description' => '',
    'email' => '',
    'enableCollaborativeInbox' => '',
    'favoriteRepliesOnTop' => '',
    'includeCustomFooter' => '',
    'includeInGlobalAddressList' => '',
    'isArchived' => '',
    'kind' => '',
    'maxMessageBytes' => 0,
    'membersCanPostAsTheGroup' => '',
    'messageDisplayFont' => '',
    'messageModerationLevel' => '',
    'name' => '',
    'primaryLanguage' => '',
    'replyTo' => '',
    'sendMessageDenyNotification' => '',
    'showInGroupDirectory' => '',
    'spamModerationLevel' => '',
    'whoCanAdd' => '',
    'whoCanAddReferences' => '',
    'whoCanApproveMembers' => '',
    'whoCanApproveMessages' => '',
    'whoCanAssignTopics' => '',
    'whoCanAssistContent' => '',
    'whoCanBanUsers' => '',
    'whoCanContactOwner' => '',
    'whoCanDeleteAnyPost' => '',
    'whoCanDeleteTopics' => '',
    'whoCanDiscoverGroup' => '',
    'whoCanEnterFreeFormTags' => '',
    'whoCanHideAbuse' => '',
    'whoCanInvite' => '',
    'whoCanJoin' => '',
    'whoCanLeaveGroup' => '',
    'whoCanLockTopics' => '',
    'whoCanMakeTopicsSticky' => '',
    'whoCanMarkDuplicate' => '',
    'whoCanMarkFavoriteReplyOnAnyTopic' => '',
    'whoCanMarkFavoriteReplyOnOwnTopic' => '',
    'whoCanMarkNoResponseNeeded' => '',
    'whoCanModerateContent' => '',
    'whoCanModerateMembers' => '',
    'whoCanModifyMembers' => '',
    'whoCanModifyTagsAndCategories' => '',
    'whoCanMoveTopicsIn' => '',
    'whoCanMoveTopicsOut' => '',
    'whoCanPostAnnouncements' => '',
    'whoCanPostMessage' => '',
    'whoCanTakeTopics' => '',
    'whoCanUnassignTopic' => '',
    'whoCanUnmarkFavoriteReplyOnAnyTopic' => '',
    'whoCanViewGroup' => '',
    'whoCanViewMembership' => ''
  ]),
  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}}/:groupUniqueId', [
  'body' => '{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}',
  'headers' => [
    'content-type' => 'application/json',
  ],
]);

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

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

$request->setContentType('application/json');
$request->setBody(json_encode([
  'allowExternalMembers' => '',
  'allowGoogleCommunication' => '',
  'allowWebPosting' => '',
  'archiveOnly' => '',
  'customFooterText' => '',
  'customReplyTo' => '',
  'customRolesEnabledForSettingsToBeMerged' => '',
  'defaultMessageDenyNotificationText' => '',
  'default_sender' => '',
  'description' => '',
  'email' => '',
  'enableCollaborativeInbox' => '',
  'favoriteRepliesOnTop' => '',
  'includeCustomFooter' => '',
  'includeInGlobalAddressList' => '',
  'isArchived' => '',
  'kind' => '',
  'maxMessageBytes' => 0,
  'membersCanPostAsTheGroup' => '',
  'messageDisplayFont' => '',
  'messageModerationLevel' => '',
  'name' => '',
  'primaryLanguage' => '',
  'replyTo' => '',
  'sendMessageDenyNotification' => '',
  'showInGroupDirectory' => '',
  'spamModerationLevel' => '',
  'whoCanAdd' => '',
  'whoCanAddReferences' => '',
  'whoCanApproveMembers' => '',
  'whoCanApproveMessages' => '',
  'whoCanAssignTopics' => '',
  'whoCanAssistContent' => '',
  'whoCanBanUsers' => '',
  'whoCanContactOwner' => '',
  'whoCanDeleteAnyPost' => '',
  'whoCanDeleteTopics' => '',
  'whoCanDiscoverGroup' => '',
  'whoCanEnterFreeFormTags' => '',
  'whoCanHideAbuse' => '',
  'whoCanInvite' => '',
  'whoCanJoin' => '',
  'whoCanLeaveGroup' => '',
  'whoCanLockTopics' => '',
  'whoCanMakeTopicsSticky' => '',
  'whoCanMarkDuplicate' => '',
  'whoCanMarkFavoriteReplyOnAnyTopic' => '',
  'whoCanMarkFavoriteReplyOnOwnTopic' => '',
  'whoCanMarkNoResponseNeeded' => '',
  'whoCanModerateContent' => '',
  'whoCanModerateMembers' => '',
  'whoCanModifyMembers' => '',
  'whoCanModifyTagsAndCategories' => '',
  'whoCanMoveTopicsIn' => '',
  'whoCanMoveTopicsOut' => '',
  'whoCanPostAnnouncements' => '',
  'whoCanPostMessage' => '',
  'whoCanTakeTopics' => '',
  'whoCanUnassignTopic' => '',
  'whoCanUnmarkFavoriteReplyOnAnyTopic' => '',
  'whoCanViewGroup' => '',
  'whoCanViewMembership' => ''
]));

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

  echo $response->getBody();
} catch (HttpException $ex) {
  echo $ex;
}
append(json_encode([
  'allowExternalMembers' => '',
  'allowGoogleCommunication' => '',
  'allowWebPosting' => '',
  'archiveOnly' => '',
  'customFooterText' => '',
  'customReplyTo' => '',
  'customRolesEnabledForSettingsToBeMerged' => '',
  'defaultMessageDenyNotificationText' => '',
  'default_sender' => '',
  'description' => '',
  'email' => '',
  'enableCollaborativeInbox' => '',
  'favoriteRepliesOnTop' => '',
  'includeCustomFooter' => '',
  'includeInGlobalAddressList' => '',
  'isArchived' => '',
  'kind' => '',
  'maxMessageBytes' => 0,
  'membersCanPostAsTheGroup' => '',
  'messageDisplayFont' => '',
  'messageModerationLevel' => '',
  'name' => '',
  'primaryLanguage' => '',
  'replyTo' => '',
  'sendMessageDenyNotification' => '',
  'showInGroupDirectory' => '',
  'spamModerationLevel' => '',
  'whoCanAdd' => '',
  'whoCanAddReferences' => '',
  'whoCanApproveMembers' => '',
  'whoCanApproveMessages' => '',
  'whoCanAssignTopics' => '',
  'whoCanAssistContent' => '',
  'whoCanBanUsers' => '',
  'whoCanContactOwner' => '',
  'whoCanDeleteAnyPost' => '',
  'whoCanDeleteTopics' => '',
  'whoCanDiscoverGroup' => '',
  'whoCanEnterFreeFormTags' => '',
  'whoCanHideAbuse' => '',
  'whoCanInvite' => '',
  'whoCanJoin' => '',
  'whoCanLeaveGroup' => '',
  'whoCanLockTopics' => '',
  'whoCanMakeTopicsSticky' => '',
  'whoCanMarkDuplicate' => '',
  'whoCanMarkFavoriteReplyOnAnyTopic' => '',
  'whoCanMarkFavoriteReplyOnOwnTopic' => '',
  'whoCanMarkNoResponseNeeded' => '',
  'whoCanModerateContent' => '',
  'whoCanModerateMembers' => '',
  'whoCanModifyMembers' => '',
  'whoCanModifyTagsAndCategories' => '',
  'whoCanMoveTopicsIn' => '',
  'whoCanMoveTopicsOut' => '',
  'whoCanPostAnnouncements' => '',
  'whoCanPostMessage' => '',
  'whoCanTakeTopics' => '',
  'whoCanUnassignTopic' => '',
  'whoCanUnmarkFavoriteReplyOnAnyTopic' => '',
  'whoCanViewGroup' => '',
  'whoCanViewMembership' => ''
]));
$request->setRequestUrl('{{baseUrl}}/:groupUniqueId');
$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}}/:groupUniqueId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}'
$headers=@{}
$headers.Add("content-type", "application/json")
$response = Invoke-RestMethod -Uri '{{baseUrl}}/:groupUniqueId' -Method PUT -Headers $headers -ContentType 'application/json' -Body '{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}'
import http.client

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

payload = "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\n}"

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

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

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

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

url = "{{baseUrl}}/:groupUniqueId"

payload = {
    "allowExternalMembers": "",
    "allowGoogleCommunication": "",
    "allowWebPosting": "",
    "archiveOnly": "",
    "customFooterText": "",
    "customReplyTo": "",
    "customRolesEnabledForSettingsToBeMerged": "",
    "defaultMessageDenyNotificationText": "",
    "default_sender": "",
    "description": "",
    "email": "",
    "enableCollaborativeInbox": "",
    "favoriteRepliesOnTop": "",
    "includeCustomFooter": "",
    "includeInGlobalAddressList": "",
    "isArchived": "",
    "kind": "",
    "maxMessageBytes": 0,
    "membersCanPostAsTheGroup": "",
    "messageDisplayFont": "",
    "messageModerationLevel": "",
    "name": "",
    "primaryLanguage": "",
    "replyTo": "",
    "sendMessageDenyNotification": "",
    "showInGroupDirectory": "",
    "spamModerationLevel": "",
    "whoCanAdd": "",
    "whoCanAddReferences": "",
    "whoCanApproveMembers": "",
    "whoCanApproveMessages": "",
    "whoCanAssignTopics": "",
    "whoCanAssistContent": "",
    "whoCanBanUsers": "",
    "whoCanContactOwner": "",
    "whoCanDeleteAnyPost": "",
    "whoCanDeleteTopics": "",
    "whoCanDiscoverGroup": "",
    "whoCanEnterFreeFormTags": "",
    "whoCanHideAbuse": "",
    "whoCanInvite": "",
    "whoCanJoin": "",
    "whoCanLeaveGroup": "",
    "whoCanLockTopics": "",
    "whoCanMakeTopicsSticky": "",
    "whoCanMarkDuplicate": "",
    "whoCanMarkFavoriteReplyOnAnyTopic": "",
    "whoCanMarkFavoriteReplyOnOwnTopic": "",
    "whoCanMarkNoResponseNeeded": "",
    "whoCanModerateContent": "",
    "whoCanModerateMembers": "",
    "whoCanModifyMembers": "",
    "whoCanModifyTagsAndCategories": "",
    "whoCanMoveTopicsIn": "",
    "whoCanMoveTopicsOut": "",
    "whoCanPostAnnouncements": "",
    "whoCanPostMessage": "",
    "whoCanTakeTopics": "",
    "whoCanUnassignTopic": "",
    "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
    "whoCanViewGroup": "",
    "whoCanViewMembership": ""
}
headers = {"content-type": "application/json"}

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

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

url <- "{{baseUrl}}/:groupUniqueId"

payload <- "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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}}/:groupUniqueId")

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  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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/:groupUniqueId') do |req|
  req.body = "{\n  \"allowExternalMembers\": \"\",\n  \"allowGoogleCommunication\": \"\",\n  \"allowWebPosting\": \"\",\n  \"archiveOnly\": \"\",\n  \"customFooterText\": \"\",\n  \"customReplyTo\": \"\",\n  \"customRolesEnabledForSettingsToBeMerged\": \"\",\n  \"defaultMessageDenyNotificationText\": \"\",\n  \"default_sender\": \"\",\n  \"description\": \"\",\n  \"email\": \"\",\n  \"enableCollaborativeInbox\": \"\",\n  \"favoriteRepliesOnTop\": \"\",\n  \"includeCustomFooter\": \"\",\n  \"includeInGlobalAddressList\": \"\",\n  \"isArchived\": \"\",\n  \"kind\": \"\",\n  \"maxMessageBytes\": 0,\n  \"membersCanPostAsTheGroup\": \"\",\n  \"messageDisplayFont\": \"\",\n  \"messageModerationLevel\": \"\",\n  \"name\": \"\",\n  \"primaryLanguage\": \"\",\n  \"replyTo\": \"\",\n  \"sendMessageDenyNotification\": \"\",\n  \"showInGroupDirectory\": \"\",\n  \"spamModerationLevel\": \"\",\n  \"whoCanAdd\": \"\",\n  \"whoCanAddReferences\": \"\",\n  \"whoCanApproveMembers\": \"\",\n  \"whoCanApproveMessages\": \"\",\n  \"whoCanAssignTopics\": \"\",\n  \"whoCanAssistContent\": \"\",\n  \"whoCanBanUsers\": \"\",\n  \"whoCanContactOwner\": \"\",\n  \"whoCanDeleteAnyPost\": \"\",\n  \"whoCanDeleteTopics\": \"\",\n  \"whoCanDiscoverGroup\": \"\",\n  \"whoCanEnterFreeFormTags\": \"\",\n  \"whoCanHideAbuse\": \"\",\n  \"whoCanInvite\": \"\",\n  \"whoCanJoin\": \"\",\n  \"whoCanLeaveGroup\": \"\",\n  \"whoCanLockTopics\": \"\",\n  \"whoCanMakeTopicsSticky\": \"\",\n  \"whoCanMarkDuplicate\": \"\",\n  \"whoCanMarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanMarkFavoriteReplyOnOwnTopic\": \"\",\n  \"whoCanMarkNoResponseNeeded\": \"\",\n  \"whoCanModerateContent\": \"\",\n  \"whoCanModerateMembers\": \"\",\n  \"whoCanModifyMembers\": \"\",\n  \"whoCanModifyTagsAndCategories\": \"\",\n  \"whoCanMoveTopicsIn\": \"\",\n  \"whoCanMoveTopicsOut\": \"\",\n  \"whoCanPostAnnouncements\": \"\",\n  \"whoCanPostMessage\": \"\",\n  \"whoCanTakeTopics\": \"\",\n  \"whoCanUnassignTopic\": \"\",\n  \"whoCanUnmarkFavoriteReplyOnAnyTopic\": \"\",\n  \"whoCanViewGroup\": \"\",\n  \"whoCanViewMembership\": \"\"\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}}/:groupUniqueId";

    let payload = json!({
        "allowExternalMembers": "",
        "allowGoogleCommunication": "",
        "allowWebPosting": "",
        "archiveOnly": "",
        "customFooterText": "",
        "customReplyTo": "",
        "customRolesEnabledForSettingsToBeMerged": "",
        "defaultMessageDenyNotificationText": "",
        "default_sender": "",
        "description": "",
        "email": "",
        "enableCollaborativeInbox": "",
        "favoriteRepliesOnTop": "",
        "includeCustomFooter": "",
        "includeInGlobalAddressList": "",
        "isArchived": "",
        "kind": "",
        "maxMessageBytes": 0,
        "membersCanPostAsTheGroup": "",
        "messageDisplayFont": "",
        "messageModerationLevel": "",
        "name": "",
        "primaryLanguage": "",
        "replyTo": "",
        "sendMessageDenyNotification": "",
        "showInGroupDirectory": "",
        "spamModerationLevel": "",
        "whoCanAdd": "",
        "whoCanAddReferences": "",
        "whoCanApproveMembers": "",
        "whoCanApproveMessages": "",
        "whoCanAssignTopics": "",
        "whoCanAssistContent": "",
        "whoCanBanUsers": "",
        "whoCanContactOwner": "",
        "whoCanDeleteAnyPost": "",
        "whoCanDeleteTopics": "",
        "whoCanDiscoverGroup": "",
        "whoCanEnterFreeFormTags": "",
        "whoCanHideAbuse": "",
        "whoCanInvite": "",
        "whoCanJoin": "",
        "whoCanLeaveGroup": "",
        "whoCanLockTopics": "",
        "whoCanMakeTopicsSticky": "",
        "whoCanMarkDuplicate": "",
        "whoCanMarkFavoriteReplyOnAnyTopic": "",
        "whoCanMarkFavoriteReplyOnOwnTopic": "",
        "whoCanMarkNoResponseNeeded": "",
        "whoCanModerateContent": "",
        "whoCanModerateMembers": "",
        "whoCanModifyMembers": "",
        "whoCanModifyTagsAndCategories": "",
        "whoCanMoveTopicsIn": "",
        "whoCanMoveTopicsOut": "",
        "whoCanPostAnnouncements": "",
        "whoCanPostMessage": "",
        "whoCanTakeTopics": "",
        "whoCanUnassignTopic": "",
        "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
        "whoCanViewGroup": "",
        "whoCanViewMembership": ""
    });

    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}}/:groupUniqueId \
  --header 'content-type: application/json' \
  --data '{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}'
echo '{
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
}' |  \
  http PUT {{baseUrl}}/:groupUniqueId \
  content-type:application/json
wget --quiet \
  --method PUT \
  --header 'content-type: application/json' \
  --body-data '{\n  "allowExternalMembers": "",\n  "allowGoogleCommunication": "",\n  "allowWebPosting": "",\n  "archiveOnly": "",\n  "customFooterText": "",\n  "customReplyTo": "",\n  "customRolesEnabledForSettingsToBeMerged": "",\n  "defaultMessageDenyNotificationText": "",\n  "default_sender": "",\n  "description": "",\n  "email": "",\n  "enableCollaborativeInbox": "",\n  "favoriteRepliesOnTop": "",\n  "includeCustomFooter": "",\n  "includeInGlobalAddressList": "",\n  "isArchived": "",\n  "kind": "",\n  "maxMessageBytes": 0,\n  "membersCanPostAsTheGroup": "",\n  "messageDisplayFont": "",\n  "messageModerationLevel": "",\n  "name": "",\n  "primaryLanguage": "",\n  "replyTo": "",\n  "sendMessageDenyNotification": "",\n  "showInGroupDirectory": "",\n  "spamModerationLevel": "",\n  "whoCanAdd": "",\n  "whoCanAddReferences": "",\n  "whoCanApproveMembers": "",\n  "whoCanApproveMessages": "",\n  "whoCanAssignTopics": "",\n  "whoCanAssistContent": "",\n  "whoCanBanUsers": "",\n  "whoCanContactOwner": "",\n  "whoCanDeleteAnyPost": "",\n  "whoCanDeleteTopics": "",\n  "whoCanDiscoverGroup": "",\n  "whoCanEnterFreeFormTags": "",\n  "whoCanHideAbuse": "",\n  "whoCanInvite": "",\n  "whoCanJoin": "",\n  "whoCanLeaveGroup": "",\n  "whoCanLockTopics": "",\n  "whoCanMakeTopicsSticky": "",\n  "whoCanMarkDuplicate": "",\n  "whoCanMarkFavoriteReplyOnAnyTopic": "",\n  "whoCanMarkFavoriteReplyOnOwnTopic": "",\n  "whoCanMarkNoResponseNeeded": "",\n  "whoCanModerateContent": "",\n  "whoCanModerateMembers": "",\n  "whoCanModifyMembers": "",\n  "whoCanModifyTagsAndCategories": "",\n  "whoCanMoveTopicsIn": "",\n  "whoCanMoveTopicsOut": "",\n  "whoCanPostAnnouncements": "",\n  "whoCanPostMessage": "",\n  "whoCanTakeTopics": "",\n  "whoCanUnassignTopic": "",\n  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",\n  "whoCanViewGroup": "",\n  "whoCanViewMembership": ""\n}' \
  --output-document \
  - {{baseUrl}}/:groupUniqueId
import Foundation

let headers = ["content-type": "application/json"]
let parameters = [
  "allowExternalMembers": "",
  "allowGoogleCommunication": "",
  "allowWebPosting": "",
  "archiveOnly": "",
  "customFooterText": "",
  "customReplyTo": "",
  "customRolesEnabledForSettingsToBeMerged": "",
  "defaultMessageDenyNotificationText": "",
  "default_sender": "",
  "description": "",
  "email": "",
  "enableCollaborativeInbox": "",
  "favoriteRepliesOnTop": "",
  "includeCustomFooter": "",
  "includeInGlobalAddressList": "",
  "isArchived": "",
  "kind": "",
  "maxMessageBytes": 0,
  "membersCanPostAsTheGroup": "",
  "messageDisplayFont": "",
  "messageModerationLevel": "",
  "name": "",
  "primaryLanguage": "",
  "replyTo": "",
  "sendMessageDenyNotification": "",
  "showInGroupDirectory": "",
  "spamModerationLevel": "",
  "whoCanAdd": "",
  "whoCanAddReferences": "",
  "whoCanApproveMembers": "",
  "whoCanApproveMessages": "",
  "whoCanAssignTopics": "",
  "whoCanAssistContent": "",
  "whoCanBanUsers": "",
  "whoCanContactOwner": "",
  "whoCanDeleteAnyPost": "",
  "whoCanDeleteTopics": "",
  "whoCanDiscoverGroup": "",
  "whoCanEnterFreeFormTags": "",
  "whoCanHideAbuse": "",
  "whoCanInvite": "",
  "whoCanJoin": "",
  "whoCanLeaveGroup": "",
  "whoCanLockTopics": "",
  "whoCanMakeTopicsSticky": "",
  "whoCanMarkDuplicate": "",
  "whoCanMarkFavoriteReplyOnAnyTopic": "",
  "whoCanMarkFavoriteReplyOnOwnTopic": "",
  "whoCanMarkNoResponseNeeded": "",
  "whoCanModerateContent": "",
  "whoCanModerateMembers": "",
  "whoCanModifyMembers": "",
  "whoCanModifyTagsAndCategories": "",
  "whoCanMoveTopicsIn": "",
  "whoCanMoveTopicsOut": "",
  "whoCanPostAnnouncements": "",
  "whoCanPostMessage": "",
  "whoCanTakeTopics": "",
  "whoCanUnassignTopic": "",
  "whoCanUnmarkFavoriteReplyOnAnyTopic": "",
  "whoCanViewGroup": "",
  "whoCanViewMembership": ""
] as [String : Any]

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

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